提交 6d9a40d8 编写于 作者: S Stephan Ewen

Renaming part 1 (scala sources only)

上级 26bc321c
......@@ -139,7 +139,7 @@
<classifier>KMeans</classifier>
<archive>
<manifestEntries>
<program-class>eu.stratosphere.examples.scala.datamining.KMeans</program-class>
<program-class>org.apache.flink.examples.scala.datamining.KMeans</program-class>
</manifestEntries>
</archive>
......@@ -161,7 +161,7 @@
<classifier>KMeansForTest</classifier>
<archive>
<manifestEntries>
<program-class>eu.stratosphere.examples.scala.testing.KMeansForTest</program-class>
<program-class>org.apache.flink.examples.scala.testing.KMeansForTest</program-class>
</manifestEntries>
</archive>
......@@ -183,7 +183,7 @@
<archive>
<manifestEntries>
<program-class>eu.stratosphere.examples.scala.graph.ComputeEdgeDegrees</program-class>
<program-class>org.apache.flink.examples.scala.graph.ComputeEdgeDegrees</program-class>
</manifestEntries>
</archive>
......@@ -205,7 +205,7 @@
<archive>
<manifestEntries>
<program-class>eu.stratosphere.examples.scala.graph.EnumTrianglesOnEdgesWithDegrees</program-class>
<program-class>org.apache.flink.examples.scala.graph.EnumTrianglesOnEdgesWithDegrees</program-class>
</manifestEntries>
</archive>
......@@ -227,7 +227,7 @@
<archive>
<manifestEntries>
<program-class>eu.stratosphere.examples.scala.relational.TPCHQuery3</program-class>
<program-class>org.apache.flink.examples.scala.relational.TPCHQuery3</program-class>
</manifestEntries>
</archive>
......@@ -249,7 +249,7 @@
<archive>
<manifestEntries>
<program-class>eu.stratosphere.examples.scala.wordcount.WordCount</program-class>
<program-class>org.apache.flink.examples.scala.wordcount.WordCount</program-class>
</manifestEntries>
</archive>
......@@ -269,7 +269,7 @@
<classifier>ConnectedComponents</classifier>
<archive>
<manifestEntries>
<program-class>eu.stratosphere.examples.scala.graph.ConnectedComponents</program-class>
<program-class>org.apache.flink.examples.scala.graph.ConnectedComponents</program-class>
</manifestEntries>
</archive>
<includes>
......@@ -289,7 +289,7 @@
<classifier>TransitiveClosureNaive</classifier>
<archive>
<manifestEntries>
<program-class>eu.stratosphere.examples.scala.graph.TransitiveClosureNaiveDescriptor</program-class>
<program-class>org.apache.flink.examples.scala.graph.TransitiveClosureNaiveDescriptor</program-class>
</manifestEntries>
</archive>
<includes>
......@@ -307,7 +307,7 @@
<classifier>TransitiveClosureRD</classifier>
<archive>
<manifestEntries>
<program-class>eu.stratosphere.examples.scala.graph.TransitiveClosureRDDescriptor</program-class>
<program-class>org.apache.flink.examples.scala.graph.TransitiveClosureRDDescriptor</program-class>
</manifestEntries>
</archive>
<includes>
......
......@@ -11,14 +11,11 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala;
package org.apache.flink.examples.scala;
/**
* This dummy class exists only to create an empty
* javadoc.jar in the stratosphere-scala-examples project.
* This is required for passing the maven central sync requirements.
*/
public class Dummy {
}
public class Dummy {}
package eu.stratosphere.examples.scala.datamining;
///**
// * Copyright (C) 2010 by the Stratosphere project (http://stratosphere.eu)
// *
// * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
// * the License. You may obtain a copy of the License at
// *
// * http://www.apache.org/licenses/LICENSE-2.0
// *
// * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on
// * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the
// * specific language governing permissions and limitations under the License.
// */
//
//package eu.stratosphere.pact4s.examples.datamining
//
//import scala.math._
//import eu.stratosphere.api.scala._
//import eu.stratosphere.api.scala.operators.DelimitedDataSinkFormat
//import eu.stratosphere.api.scala.operators.DelimitedDataSourceFormat
//import eu.stratosphere.api.common.ProgramDescription
//import eu.stratosphere.client.LocalExecutor
//import eu.stratosphere.api.scala.analysis.GlobalSchemaPrinter
//
//
//object RunLanczos {
// def main(args: Array[String]) {
// val plan = KMeans.getPlan(20,
// "file:///home/aljoscha/kmeans-points",
// "file:///home/aljoscha/kmeans-clusters",
// "file:///home/aljoscha/kmeans-output")
//
// GlobalSchemaPrinter.printSchema(plan)
// LocalExecutor.execute(plan)
//
// System.exit(0)
// }
//}
//
//class LanczosDescriptor extends ScalaProgram with ProgramDescription {
// override def getDescription = "[-k <int:10>] [-m <int:10>] [-eps <double:0.05>] -A <file> -b <file> -lamba <file> -Y <file>"
//
// override def getScalaPlan(args: Args) = LanczosSO.getPlan(args("k", "10").toInt, args("m", "10").toInt, args("eps", "0.05").toDouble, args("A"), args("b"), args("lambda"), args("Y"))
//}
//
//abstract sealed class Cell {
// val row: Int; val col: Int; val value: Double
// def isAlpha = false; def isBeta = false; def isQ = false; def isV = false; def isOther = false
//}
//case class AlphaCell(row: Int, col: Int, value: Double) extends Cell { override def isAlpha = true }
//case class BetaCell(row: Int, col: Int, value: Double) extends Cell { override def isBeta = true }
//case class QCell(row: Int, col: Int, value: Double) extends Cell { override def isQ = true }
//case class VCell(row: Int, col: Int, value: Double) extends Cell { override def isV = true }
//case class OtherCell(row: Int, col: Int, value: Double) extends Cell { override def isOther = true }
//
//
//object LanczosSO {
//
//
// def getPlan(k: Int, m: Int, ε: Double, inputA: String, inputB: String, outputLambda: String, outputY: String) = {
//
// val A = DataSource(inputA, DelimitedDataSourceFormat(parseCell))
// val b = DataSource(inputB, DelimitedDataSourceFormat(parseCell))
//
// val αʹβʹvʹ = mulVS(b, normV(b) map { 1 / _ }) flatMap { c =>
// val v0: Cell = VCell(0, c.col, 0)
// val v1: Cell = VCell(1, c.col, c.value)
//
// if (c.col == 0)
// Seq(BetaCell(0, 0, 0), v0, v1)
// else
// Seq(v0, v1)
// }
//
// val (α, β, v) = splitαβv(stepI repeat (n = m, s0 = αʹβʹvʹ))
//
// val t = triDiag(α, β filter { _.col > 0 })
// val (q, d) = decompose(t)
//
// val diag = d filter { c => c.col == c.row }
// val λ = diag map { (0, _) } groupBy { _._1 } reduce { eigenValues =>
// val highToLow = eigenValues.map(_._2).toSeq.sortBy(c => abs(c.value))(Ordering[Double].reverse)
// highToLow take (k) map { c => OtherCell(0, c.col, c.value): Cell }
// } flatMap { c => c }
//
// val y = mulMM(v, q join λ on { _.col } isEqualTo { _.col } map { (q, _) => q })
//
// val λsink = λ.write(outputLambda, DelimitedDataSinkFormat(formatCell))
// val ysink = y.write(outputY, DelimitedDataSinkFormat(formatCell))
//
// new ScalaPlan(Seq(λsink, ysink), "LanczosSO")
// }
//
// override def outputs = Seq(λsink <~ λ, ysink <~ y)
//
// def stepI = (αʹβʹv: DataStream[Cell]) => {
//
// val i = 1 // need current iteration!
//
// val (αʹ, βʹ, v) = splitαβv(αʹβʹv)
//
// val vᵢ = v filter { _.row == i }
// val vᵢᐨ = v filter { _.row == i - 1 }
// val βᵢᐨ = βʹ filter { c => c.col == i - 1 } map { _.value }
//
// val vᵢᐩʹʹʹ = mulMV(A, vᵢ)
// val αᵢ = dot(vᵢ, vᵢᐩʹʹʹ)
// val vᵢᐩʹʹ = sub(vᵢᐩʹʹʹ, sub(mulVS(vᵢᐨ, βᵢᐨ), mulVS(vᵢ, αᵢ)))
// val βᵢʹ = normV(vᵢᐩʹʹ)
//
// val α = αʹ union (αᵢ map { AlphaCell(0, i, _): Cell })
// val t = triDiag(α, βʹ union (βᵢʹ map { BetaCell(0, i, _): Cell }))
// val (q, d) = decompose(t)
//
// val βᵢʹvᵢᐩʹʹ = (βᵢʹ map { x => BetaCell(0, 0, x): Cell }) union vᵢᐩʹʹ
//
// val βᵢvᵢᐩʹ = stepJ(i, v, q, normM(t)) repeat (n = i, s0 = βᵢʹvᵢᐩʹʹ)
// val βᵢ = βᵢvᵢᐩʹ filter { _.isBeta } map { _.value }
// val vᵢᐩʹ = βᵢvᵢᐩʹ filter { _.isV }
//
// val β = βʹ union (βᵢ map { BetaCell(0, i, _): Cell })
// val vᵢᐩ = mulVS(vᵢᐩʹ, βᵢ map { 1 / _ })
// val vᐩ = v union vᵢᐩ
//
// α union β union vᐩ
// }
//
// def stepJ = (i: Int, v: DataStream[Cell], q: DataStream[Cell], normT: DataStream[Double]) => {
//
// val qvt = v union q union (normT map { t => OtherCell(0, 0, t): Cell })
//
// (βᵢʹvᵢᐩʹʹ: DataStream[Cell]) => {
//
// val j = 1 // need current iteration!
//
// // Would it be better to union+reduce instead of cogroup here?
// (qvt map { (0, _) }) cogroup (βᵢʹvᵢᐩʹʹ map { (0, _) }) on { _._1 } isEqualTo { _._1 } flatMap { (qvt, βᵢʹvᵢᐩʹʹ) =>
//
// val (q, vt) = qvt.toSeq map { _._2 } partition { _.isQ }
// val (v, t) = vt partition { _.isV }
// val qij = q.find(c => c.row == i && c.col == j).get.value
// val normT = t.head.value
//
// val (βᵢʹs, vᵢᐩʹʹ) = βᵢʹvᵢᐩʹʹ.toSeq map { _._2 } partition { _.isBeta }
// val βᵢʹ = βᵢʹs.head.value
//
// if (βᵢʹ * abs(qij) <= sqrt(ε) * normT) {
// val r = mulMV(v, q filter { _.col == j })
//
// val vᵢᐩʹ = sub(vᵢᐩʹʹ, mulVS(r, dot(r, vᵢᐩʹʹ)))
// val βᵢ = BetaCell(0, i, norm(vᵢᐩʹ)): Cell
//
// βᵢ +: vᵢᐩʹ
//
// } else {
// βᵢʹs ++ vᵢᐩʹʹ
// }
// }
// }
// }
//
// def splitαβv(αβv: DataStream[Cell]) = (αβv filter { _.isAlpha }, αβv filter { _.isBeta }, αβv filter { _.isV })
//
// def triDiag(α: DataStream[Cell], β: DataStream[Cell]) = {
// val diag = α map { c => OtherCell(c.col, c.col, c.value): Cell }
// val lower = β map { c => OtherCell(c.col, c.col - 1, c.value): Cell }
// val upper = β map { c => OtherCell(c.col - 1, c.col, c.value): Cell }
// diag union lower union upper
// }
//
// def normV(x: DataStream[Cell]): DataStream[Double] = x map { _.value} //throw new RuntimeException("Not implemented")
// def normM(x: DataStream[Cell]): DataStream[Double] = x map { _.value} //throw new RuntimeException("Not implemented")
// def dot(x: DataStream[Cell], y: DataStream[Cell]): DataStream[Double] = x map { _.value} //throw new RuntimeException("Not implemented")
// def sub(x: DataStream[Cell], y: DataStream[Cell]): DataStream[Cell] = x //throw new RuntimeException("Not implemented")
// def mulSS(x: DataStream[Double], y: DataStream[Double]): DataStream[Double] = x //throw new RuntimeException("Not implemented")
// def mulVS(x: DataStream[Cell], y: DataStream[Double]): DataStream[Cell] = x //throw new RuntimeException("Not implemented")
// def mulMM(x: DataStream[Cell], y: DataStream[Cell]): DataStream[Cell] = x //throw new RuntimeException("Not implemented")
// def mulMV(x: DataStream[Cell], y: DataStream[Cell]): DataStream[Cell] = x //throw new RuntimeException("Not implemented")
// def decompose(t: DataStream[Cell]): (DataStream[Cell], DataStream[Cell]) = (t, t) // throw new RuntimeException("Not implemented")
//
// def norm(x: Seq[Cell]): Double = 0 //throw new RuntimeException("Not implemented")
// def dot(x: Seq[Cell], y: Seq[Cell]): Double = 0 //throw new RuntimeException("Not implemented")
// def sub(x: Seq[Cell], y: Seq[Cell]): Seq[Cell] = Seq() //throw new RuntimeException("Not implemented")
// def mulVS(x: Seq[Cell], y: Double): Seq[Cell] = Seq() //throw new RuntimeException("Not implemented")
// def mulMV(x: Seq[Cell], y: Seq[Cell]): Seq[Cell] = Seq() //throw new RuntimeException("Not implemented")
//
//
// val CellInputPattern = """(\d+)\|(\d+)\|(\d+\.\d+)\|""".r
//
// def parseCell = (line: String) => line match {
// case CellInputPattern(row, col, value) => OtherCell(row.toInt, col.toInt, value.toDouble): Cell
// }
//
// def formatCell = (cell: Cell) => "%d|%d|%.2f|".format(cell.row, cell.col, cell.value)
//}
//
......@@ -11,11 +11,11 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.datamining
package org.apache.flink.examples.scala.datamining
import scala.math._
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
abstract class BatchGradientDescent(eps: Double, eta: Double, lambda: Double, examplesInput: String, weightsInput: String, weightsOutput: String) extends Serializable {
......
......@@ -13,14 +13,14 @@
* ********************************************************************************************************************
*/
package eu.stratosphere.examples.scala.datamining
package org.apache.flink.examples.scala.datamining
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
class KMeans extends Program with ProgramDescription with Serializable {
......
......@@ -11,14 +11,14 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.graph
package org.apache.flink.examples.scala.graph
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
/**
* Annotates edges with associated vertex degrees.
......
......@@ -11,12 +11,13 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.graph;
package org.apache.flink.examples.scala.graph;
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
object RunConnectedComponents {
def main(pArgs: Array[String]) {
......
......@@ -11,17 +11,16 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.graph
package org.apache.flink.examples.scala.graph
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import scala.math._
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import eu.stratosphere.api.scala.analysis.GlobalSchemaPrinter
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
import org.apache.flink.api.scala.analysis.GlobalSchemaPrinter
object RunEnumTrianglesOnEdgesWithDegrees {
def main(args: Array[String]) {
......
......@@ -13,14 +13,15 @@
* ********************************************************************************************************************
*/
package eu.stratosphere.examples.scala.graph
package org.apache.flink.examples.scala.graph
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.DataSource
import eu.stratosphere.api.scala.operators._
import eu.stratosphere.api.common.{ ProgramDescription, Program }
import eu.stratosphere.api.scala.operators.CsvInputFormat
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.DataSource
import org.apache.flink.api.scala.operators._
import org.apache.flink.api.scala.operators.CsvInputFormat
class LineRank extends Program with Serializable {
......
......@@ -13,12 +13,13 @@
* ********************************************************************************************************************
*/
package eu.stratosphere.examples.scala.graph;
package org.apache.flink.examples.scala.graph;
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
/**
* An example program computing the page rank for each vertex in a graph.
......
......@@ -13,15 +13,17 @@
* ********************************************************************************************************************
*/
package eu.stratosphere.examples.scala.graph;
package org.apache.flink.examples.scala.graph;
import scala.math._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
import org.apache.flink.api.scala.analysis.GlobalSchemaPrinter
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.api.scala.analysis.GlobalSchemaPrinter
import scala.math._
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import eu.stratosphere.api.common.Plan
import eu.stratosphere.api.java.record.operators.DeltaIteration
......
......@@ -11,14 +11,14 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.graph;
package org.apache.flink.examples.scala.graph;
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
class TransitiveClosureNaive extends Program with ProgramDescription with Serializable {
......
......@@ -11,14 +11,14 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.iterative
package org.apache.flink.examples.scala.iterative
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
/**
* Example of using the bulk iteration with termination criterion with the
......
......@@ -11,14 +11,14 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.relational;
package org.apache.flink.examples.scala.relational;
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
/**
......
......@@ -11,14 +11,14 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.relational;
package org.apache.flink.examples.scala.relational;
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
/**
* Implements the following relational OLAP query as PACT program:
......
......@@ -11,7 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.testing
package org.apache.flink.examples.scala.testing
// Uncomment if you need to rebuild it for PackagedProgramEndToEndTest
//
......
......@@ -11,14 +11,14 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.wordcount
package org.apache.flink.examples.scala.wordcount
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
/**
......
......@@ -11,14 +11,14 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.wordcount
package org.apache.flink.examples.scala.wordcount
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
/**
......
......@@ -11,7 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.examples.scala.wordcount
package org.apache.flink.examples.scala.wordcount
import eu.stratosphere.client.LocalExecutor
import eu.stratosphere.api.common.Program
......@@ -20,8 +20,8 @@ import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.types.IntValue
import eu.stratosphere.types.StringValue
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.operators._
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.operators._
/**
......
......@@ -11,7 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators;
package org.apache.flink.api.scala.operators;
import java.lang.annotation.Annotation;
import java.util.Arrays;
......
/*
/***********************************************************************************************************************
* Copyright (C) 2010-2013 by the Stratosphere project (http://stratosphere.eu)
*
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
......@@ -9,9 +9,11 @@
* Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on
* an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the
* specific language governing permissions and limitations under the License.
*/
**********************************************************************************************************************/
package eu.stratosphere.api.scala
package org.apache.flink.api.scala
import collection.JavaConversions.asScalaIterator
import eu.stratosphere.api.common.operators.util.FieldSet
import eu.stratosphere.api.common.operators._
......@@ -21,7 +23,13 @@ import eu.stratosphere.api.java.record.operators.BulkIteration.PartialSolutionPl
import eu.stratosphere.api.java.record.operators.DeltaIteration.{WorksetPlaceHolder, SolutionSetPlaceHolder}
import eu.stratosphere.api.java.record.operators.GenericDataSink
import eu.stratosphere.api.java.record.operators.ReduceOperator.Combinable
import collection.JavaConversions.asScalaIterator
import eu.stratosphere.api.java.record.functions.FunctionAnnotation.ConstantFields
import eu.stratosphere.api.java.record.functions.FunctionAnnotation.ConstantFieldsExcept
import eu.stratosphere.api.java.record.functions.FunctionAnnotation.ConstantFieldsFirst
import eu.stratosphere.api.java.record.functions.FunctionAnnotation.ConstantFieldsFirstExcept
import eu.stratosphere.api.java.record.functions.FunctionAnnotation.ConstantFieldsSecond
import eu.stratosphere.api.java.record.functions.FunctionAnnotation.ConstantFieldsSecondExcept
import eu.stratosphere.api.java.record.operators.ReduceOperator.Combinable
object AnnotationUtil {
val visited = collection.mutable.Set[Operator[_]]()
......
......@@ -11,17 +11,25 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala
package org.apache.flink.api.scala
import language.experimental.macros
import scala.util.DynamicVariable
import scala.reflect.macros.Context
import eu.stratosphere.api.scala.analysis._
import eu.stratosphere.api.common.operators.util.{ FieldSet => PactFieldSet }
import scala.util.DynamicVariable
import org.apache.flink.api.scala.codegen.MacroContextHolder
import org.apache.flink.api.scala.analysis._
import org.apache.flink.api.scala.analysis.FieldSet.toSeq
import org.apache.flink.api.scala.analysis.UDF2
import org.apache.flink.api.scala.analysis.UDF1
import org.apache.flink.api.scala.analysis.FieldSelector
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.scala.codegen.MacroContextHolder
import eu.stratosphere.api.common.operators.util.{FieldSet => PactFieldSet}
import eu.stratosphere.types.Record
case class KeyCardinality(
key: FieldSelector,
isUnique: Boolean,
......
......@@ -11,21 +11,17 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala
package org.apache.flink.api.scala
import language.experimental.macros
import scala.reflect.macros.Context
import org.apache.flink.api.scala.operators._
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.scala.operators.CoGroupDataSet
import eu.stratosphere.api.scala.operators.CrossDataSet
import eu.stratosphere.api.scala.operators.JoinDataSet
import eu.stratosphere.api.scala.operators.MapMacros
import eu.stratosphere.api.scala.operators.KeyedDataSet
import eu.stratosphere.api.scala.operators.ReduceMacros
import eu.stratosphere.api.scala.operators.UnionOperator
import eu.stratosphere.api.scala.operators.IterateMacros
import eu.stratosphere.api.scala.operators.WorksetIterateMacros
import eu.stratosphere.types.Record
class DataSet[T] (val contract: Operator[Record] with ScalaOperator[T, Record]) {
def cogroup[RightIn](rightInput: DataSet[RightIn]) =
......
......@@ -11,16 +11,19 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala
package org.apache.flink.api.scala
import java.net.URI
import eu.stratosphere.api.scala.analysis._
import eu.stratosphere.api.common.io.OutputFormat
import org.apache.flink.api.scala.analysis._
import eu.stratosphere.configuration.Configuration
import eu.stratosphere.api.common.io.FileOutputFormat
import eu.stratosphere.types.Record
import eu.stratosphere.api.common.operators.base.GenericDataSinkBase
import eu.stratosphere.api.java.record.operators.FileDataSink
import eu.stratosphere.api.common.io.OutputFormat
object DataSinkOperator {
val DEFAULT_DATASINKOPERATOR_NAME = "<Unnamed Scala Data Sink>"
......
......@@ -11,19 +11,23 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala
package org.apache.flink.api.scala
import java.net.URI
import eu.stratosphere.api.scala.analysis._
import eu.stratosphere.api.scala.functions._
import collection.JavaConversions._
import org.apache.flink.api.scala.analysis._
import org.apache.flink.api.scala.functions._
import org.apache.flink.api.scala.analysis.UDF0
import eu.stratosphere.types._
import eu.stratosphere.types.parser._
import eu.stratosphere.api.common.io.InputFormat
import eu.stratosphere.api.java.record.operators.{CollectionDataSource => JavaCollectionDataSource, FileDataSource}
import eu.stratosphere.configuration.Configuration
import eu.stratosphere.api.common.io.FileInputFormat
import eu.stratosphere.api.common.io.GenericInputFormat
import eu.stratosphere.api.scala.operators.TextInputFormat
import collection.JavaConversions._
import eu.stratosphere.api.java.record.operators.{CollectionDataSource => JavaCollectionDataSource}
import eu.stratosphere.api.common.io.InputFormat
import org.apache.flink.api.scala.operators.TextInputFormat
object DataSource {
......
......@@ -11,17 +11,19 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala
package org.apache.flink.api.scala
import java.lang.annotation.Annotation
import org.apache.flink.api.scala.analysis.UDF
import org.apache.flink.api.scala.analysis.UDF0
import org.apache.flink.api.scala.analysis.UDF1
import org.apache.flink.api.scala.analysis.UDF2
import org.apache.flink.api.scala.analysis.FieldSelector
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.scala.analysis.UDF
import eu.stratosphere.api.scala.analysis.UDF1
import eu.stratosphere.api.scala.analysis.UDF2
import eu.stratosphere.api.scala.analysis.FieldSelector
import eu.stratosphere.compiler.dag.OptimizerNode
import eu.stratosphere.api.common.operators.AbstractUdfOperator
import eu.stratosphere.api.scala.analysis.UDF0
import eu.stratosphere.api.common.operators.Union
import eu.stratosphere.types.Record
import eu.stratosphere.types.{Nothing => JavaNothing}
......
......@@ -11,25 +11,27 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala
package org.apache.flink.api.scala
import scala.collection.JavaConversions.asJavaCollection
import java.util.Calendar
import eu.stratosphere.api.common.Plan
import eu.stratosphere.compiler.plan.OptimizedPlan
import eu.stratosphere.compiler.postpass.RecordModelPostPass
import java.util.Calendar
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.scala.analysis.GlobalSchemaGenerator
import eu.stratosphere.api.scala.analysis.postPass.GlobalSchemaOptimizer
import eu.stratosphere.api.common.Program
import eu.stratosphere.api.common.ProgramDescription
import eu.stratosphere.types.Record
class ScalaPlan(scalaSinks: Seq[ScalaSink[_]], scalaJobName: String = "PACT SCALA Job at " + Calendar.getInstance()
import org.apache.flink.api.scala.analysis.GlobalSchemaGenerator
import org.apache.flink.api.scala.analysis.postPass.GlobalSchemaOptimizer
class ScalaPlan(scalaSinks: Seq[ScalaSink[_]], scalaJobName: String = "Flink Scala Job at " + Calendar.getInstance()
.getTime()) extends Plan(asJavaCollection(ScalaPlan.setAnnotations(scalaSinks) map { _.sink }), scalaJobName) {
val pactSinks = scalaSinks map { _.sink.asInstanceOf[Operator[Record] with ScalaOperator[_, _]] }
new GlobalSchemaGenerator().initGlobalSchema(pactSinks)
override def getPostPassClassName() = "eu.stratosphere.api.scala.ScalaPostPass";
override def getPostPassClassName() = "org.apache.flink.api.scala.ScalaPostPass";
}
......
......@@ -11,24 +11,26 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis
package org.apache.flink.api.scala.analysis
import scala.collection.JavaConversions.asScalaBuffer
import scala.collection.JavaConversions.collectionAsScalaIterable
import eu.stratosphere.api.scala.analysis._
import eu.stratosphere.api.scala.operators.Annotations
import eu.stratosphere.compiler.dag._
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.common.operators.Union
import eu.stratosphere.api.common.operators.DualInputOperator
import eu.stratosphere.api.common.operators.SingleInputOperator
import eu.stratosphere.api.java.record.operators._
import eu.stratosphere.api.scala._
import eu.stratosphere.api.common.operators.base.{BulkIterationBase => BulkIteration, DeltaIterationBase => DeltaIteration, GenericDataSinkBase, GenericDataSourceBase}
import eu.stratosphere.api.common.operators.Union
import eu.stratosphere.api.java.record.operators.CrossOperator
import eu.stratosphere.api.java.record.operators.CoGroupOperator
import eu.stratosphere.api.java.record.operators.JoinOperator
import eu.stratosphere.api.java.record.operators.MapOperator
import eu.stratosphere.api.java.record.operators.ReduceOperator
import eu.stratosphere.types.Record
import eu.stratosphere.types.{Nothing => JavaNothing}
import scala.Some
import scala.Some
import org.apache.flink.api.scala._
object Extractors {
......
......@@ -11,10 +11,9 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis
package org.apache.flink.api.scala.analysis
import scala.language.experimental.macros
import scala.language.implicitConversions
import FieldSet.toSeq
/**
* Instances of this class are typically created by the field selector macros fieldSelectorImpl
......
......@@ -11,10 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis
import scala.language.postfixOps
import scala.language.implicitConversions
package org.apache.flink.api.scala.analysis
abstract sealed class Field extends Serializable {
val localPos: Int
......
......@@ -11,17 +11,19 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis
package org.apache.flink.api.scala.analysis
import java.util.{List => JList}
import scala.Some
import org.apache.flink.api.scala._
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.scala._
import eu.stratosphere.api.java.record.operators._
import eu.stratosphere.api.common.operators.base.{BulkIterationBase => BulkIteration, DeltaIterationBase => DeltaIteration, GenericDataSourceBase, MapOperatorBase}
import eu.stratosphere.api.common.operators.Union
import eu.stratosphere.types.Record
import scala.Some
import scala.Some
class GlobalSchemaGenerator {
......
......@@ -11,18 +11,29 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis
package org.apache.flink.api.scala.analysis
import scala.language.existentials
import org.apache.commons.logging.{LogFactory, Log}
import scala.collection.JavaConversions.collectionAsScalaIterable
import scala.Array.canBuildFrom
import eu.stratosphere.api.common.Plan
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.common.operators.DualInputOperator
import eu.stratosphere.api.common.operators.SingleInputOperator
import eu.stratosphere.api.common.operators.base.{BulkIterationBase => BulkIteration, DeltaIterationBase => DeltaIteration}
import org.apache.commons.logging.{LogFactory, Log}
import eu.stratosphere.api.java.record.operators.GenericDataSink
import eu.stratosphere.api.common.operators.base.{BulkIterationBase => BulkIteration}
import eu.stratosphere.api.common.operators.base.{DeltaIterationBase => DeltaIteration}
import Extractors.DataSourceNode
import Extractors.DataSinkNode
import Extractors.DeltaIterationNode
import Extractors.JoinNode
import Extractors.MapNode
import Extractors.ReduceNode
import Extractors.UnionNode
object GlobalSchemaPrinter {
......
......@@ -11,9 +11,11 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis
package org.apache.flink.api.scala.analysis
import scala.collection.mutable
import scala.util.Either.MergeableEither
abstract class UDF[R] extends Serializable {
......
......@@ -11,16 +11,18 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis
package org.apache.flink.api.scala.analysis
import scala.language.experimental.macros
import scala.language.postfixOps
import scala.language.experimental.macros
import org.apache.flink.api.scala.codegen.Util
import eu.stratosphere.types.{Key => PactKey}
import eu.stratosphere.types.Record
import eu.stratosphere.types.{Value => PactValue}
import eu.stratosphere.types.StringValue
import eu.stratosphere.api.scala.codegen.Util
abstract class UDT[T] extends Serializable {
protected def createSerializer(indexMap: Array[Int]): UDTSerializer[T]
......
package org.apache.flink.api.scala.analysis.postPass;
// Comment out because this is not working right now
///**
// * Copyright (C) 2010 by the Stratosphere project (http://stratosphere.eu)
......
package org.apache.flink.api.scala.analysis.postPass;
// Comment out because this is not working right now
///**
// * Copyright (C) 2010 by the Stratosphere project (http://stratosphere.eu)
......
......@@ -11,10 +11,19 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis.postPass
package org.apache.flink.api.scala.analysis.postPass
import scala.language.implicitConversions
import scala.Some
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.analysis.FieldSelector
import org.apache.flink.api.scala.analysis.UDF
import org.apache.flink.api.scala.analysis.UDF0
import org.apache.flink.api.scala.analysis.UDF1
import org.apache.flink.api.scala.analysis.UDF2
import eu.stratosphere.api.java.record.operators.CoGroupOperator
import eu.stratosphere.api.java.record.operators.CrossOperator
import eu.stratosphere.api.java.record.operators.MapOperator
......@@ -33,16 +42,8 @@ import eu.stratosphere.compiler.dag.PactConnection
import eu.stratosphere.compiler.dag.GroupReduceNode
import eu.stratosphere.compiler.dag.SinkJoiner
import eu.stratosphere.compiler.dag.WorksetIterationNode
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.analysis.FieldSelector
import eu.stratosphere.api.scala.analysis.UDF
import eu.stratosphere.api.scala.analysis.UDF0
import eu.stratosphere.api.scala.analysis.UDF1
import eu.stratosphere.api.scala.analysis.UDF2
import eu.stratosphere.api.common.operators.Union
import eu.stratosphere.api.common.operators.base.{BulkIterationBase => BulkIteration, DeltaIterationBase => DeltaIteration, GenericDataSinkBase, GenericDataSourceBase}
import scala.Some
object Extractors {
......
package org.apache.flink.api.scala.analysis.postPass;
// Comment out because this is not working right now
///**
// * Copyright (C) 2010 by the Stratosphere project (http://stratosphere.eu)
......
......@@ -11,14 +11,16 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis.postPass
package org.apache.flink.api.scala.analysis.postPass
import scala.collection.JavaConversions.asScalaBuffer
import scala.collection.JavaConversions.collectionAsScalaIterable
import org.apache.flink.api.scala.ScalaOperator
import eu.stratosphere.compiler.dag.OptimizerNode
import eu.stratosphere.compiler.plan.OptimizedPlan
import eu.stratosphere.api.scala.ScalaOperator
trait GlobalSchemaOptimizer {
......
......@@ -11,11 +11,14 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis.postPass
package org.apache.flink.api.scala.analysis.postPass
import scala.Array.canBuildFrom
import scala.collection.JavaConversions.asScalaBuffer
import scala.collection.JavaConversions.collectionAsScalaIterable
import org.apache.commons.logging.{LogFactory, Log}
import Extractors.CoGroupNode
import Extractors.CrossNode
import Extractors.DataSinkNode
......@@ -23,17 +26,18 @@ import Extractors.DataSourceNode
import Extractors.JoinNode
import Extractors.MapNode
import Extractors.ReduceNode
import org.apache.flink.api.scala.analysis.FieldSet
import org.apache.flink.api.scala.analysis.FieldSelector
import eu.stratosphere.compiler.dag.BinaryUnionNode
import eu.stratosphere.compiler.dag.OptimizerNode
import eu.stratosphere.compiler.dag.SinkJoiner
import eu.stratosphere.compiler.plan.OptimizedPlan
import eu.stratosphere.api.scala.analysis.FieldSet
import eu.stratosphere.api.scala.analysis.FieldSelector
import eu.stratosphere.api.common.Plan
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.common.operators.SingleInputOperator
import eu.stratosphere.api.common.operators.DualInputOperator
import org.apache.commons.logging.{LogFactory, Log}
import eu.stratosphere.api.java.record.operators.GenericDataSink
object GlobalSchemaPrinter {
......
......@@ -11,17 +11,17 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.analysis.postPass
package org.apache.flink.api.scala.analysis.postPass
import scala.language.reflectiveCalls
import scala.collection.JavaConversions._
import eu.stratosphere.api.scala.analysis._
import org.apache.flink.api.scala.analysis._
import eu.stratosphere.compiler.dag._
import eu.stratosphere.compiler.plan.OptimizedPlan
object OutputSets {
import Extractors._
......
......@@ -11,7 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
class Counter {
private var value: Int = 0
......
......@@ -11,7 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import scala.reflect.macros.Context
......
......@@ -11,7 +11,8 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import scala.reflect.macros.Context
trait Loggers[C <: Context] { this: MacroContextHolder[C] =>
......
......@@ -11,7 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import scala.reflect.macros.Context
......
......@@ -11,11 +11,12 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import scala.reflect.macros.Context
import scala.Option.option2Iterable
import eu.stratosphere.api.scala.analysis.FieldSelector
import org.apache.flink.api.scala.analysis.FieldSelector
trait SelectionExtractor[C <: Context] { this: MacroContextHolder[C] with UDTDescriptors[C] with UDTAnalyzer[C] with Loggers[C] with TreeGen[C] =>
import c.universe._
......
......@@ -11,7 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import scala.reflect.macros.Context
......
......@@ -11,13 +11,15 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import scala.language.postfixOps
import scala.reflect.macros.Context
import org.apache.flink.api.scala.analysis.UDTSerializer
import eu.stratosphere.types.Record
import eu.stratosphere.api.scala.analysis.UDTSerializer
trait SerializerGen[C <: Context] { this: MacroContextHolder[C] with UDTDescriptors[C] with UDTAnalyzer[C] with TreeGen[C] with SerializeMethodGen[C] with DeserializeMethodGen[C] with Loggers[C] =>
import c.universe._
......
......@@ -11,7 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import scala.language.implicitConversions
......
......@@ -11,12 +11,14 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import scala.Option.option2Iterable
import scala.collection.GenTraversableOnce
import scala.collection.mutable
import scala.reflect.macros.Context
import scala.util.DynamicVariable
import eu.stratosphere.types.BooleanValue
import eu.stratosphere.types.ByteValue
import eu.stratosphere.types.CharValue
......@@ -26,7 +28,7 @@ import eu.stratosphere.types.IntValue
import eu.stratosphere.types.StringValue
import eu.stratosphere.types.LongValue
import eu.stratosphere.types.ShortValue
import scala.Option.option2Iterable
trait UDTAnalyzer[C <: Context] { this: MacroContextHolder[C] with UDTDescriptors[C] with Loggers[C] =>
import c.universe._
......
......@@ -11,7 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import scala.language.postfixOps
......
......@@ -11,10 +11,12 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import scala.reflect.macros.Context
import eu.stratosphere.api.scala.analysis.UDT
import org.apache.flink.api.scala.analysis.UDT
import eu.stratosphere.types.ListValue
import eu.stratosphere.types.Record
......
......@@ -11,11 +11,12 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.codegen
package org.apache.flink.api.scala.codegen
import language.experimental.macros
import scala.reflect.macros.Context
import eu.stratosphere.api.scala.analysis.UDT
import org.apache.flink.api.scala.analysis.UDT
object Util {
......
......@@ -11,14 +11,18 @@
* specific language governing permissions and limitations under the License.
*/
package eu.stratosphere.api.scala.functions
package org.apache.flink.api.scala.functions
import java.util.{Iterator => JIterator}
import org.apache.flink.api.scala.analysis.{UDTSerializer, UDT}
import org.apache.flink.api.scala.analysis.UDF2
import eu.stratosphere.api.scala.analysis.{UDTSerializer, UDF2, UDT}
import eu.stratosphere.api.java.record.functions.{CoGroupFunction => JCoGroupFunction}
import eu.stratosphere.types.Record
import eu.stratosphere.util.Collector
import eu.stratosphere.configuration.Configuration;
import java.util.{Iterator => JIterator}
import eu.stratosphere.configuration.Configuration
abstract class CoGroupFunctionBase[LeftIn: UDT, RightIn: UDT, Out: UDT] extends JCoGroupFunction with Serializable {
val leftInputUDT = implicitly[UDT[LeftIn]]
......
......@@ -11,10 +11,12 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.functions
package org.apache.flink.api.scala.functions
import org.apache.flink.api.scala.analysis.{UDTSerializer, UDT}
import org.apache.flink.api.scala.analysis.UDF2
import eu.stratosphere.api.java.record.functions.{CrossFunction => JCrossFunction}
import eu.stratosphere.api.scala.analysis.{UDTSerializer, UDF2, UDT}
import eu.stratosphere.types.Record
import eu.stratosphere.util.Collector
......
......@@ -11,11 +11,11 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.functions
package org.apache.flink.api.scala.functions
import java.util.{ Iterator => JIterator }
import eu.stratosphere.api.scala.analysis.UDTSerializer
import org.apache.flink.api.scala.analysis.UDTSerializer
import eu.stratosphere.types.Record
......
......@@ -11,10 +11,12 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.functions
package org.apache.flink.api.scala.functions
import org.apache.flink.api.scala.analysis.{UDTSerializer, UDT}
import org.apache.flink.api.scala.analysis.UDF2
import eu.stratosphere.api.java.record.functions.{JoinFunction => JJoinFunction}
import eu.stratosphere.api.scala.analysis.{UDTSerializer, UDF2, UDT}
import eu.stratosphere.types.Record
import eu.stratosphere.util.Collector
......
......@@ -11,9 +11,11 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.functions
package org.apache.flink.api.scala.functions
import org.apache.flink.api.scala.analysis.{UDTSerializer, UDT}
import org.apache.flink.api.scala.analysis.UDF1
import eu.stratosphere.api.scala.analysis.{UDTSerializer, UDT, UDF1}
import eu.stratosphere.api.java.record.functions.{MapFunction => JMapFunction}
import eu.stratosphere.types.Record
import eu.stratosphere.util.Collector
......
......@@ -11,15 +11,19 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.functions
package org.apache.flink.api.scala.functions
import java.util.{ Iterator => JIterator }
import eu.stratosphere.api.scala.analysis.{UDTSerializer, UDF1, FieldSelector, UDT}
import scala.Iterator
import org.apache.flink.api.scala.analysis.{UDTSerializer, FieldSelector, UDT}
import org.apache.flink.api.scala.analysis.UDF1
import eu.stratosphere.api.java.record.functions.{ReduceFunction => JReduceFunction}
import eu.stratosphere.types.Record
import eu.stratosphere.util.Collector
import scala.Iterator
abstract class ReduceFunctionBase[In: UDT, Out: UDT] extends JReduceFunction with Serializable {
......
......@@ -10,7 +10,7 @@
* an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
package org.apache.flink.api.scala.operators
import java.lang.reflect.Field
......
......@@ -11,27 +11,29 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
package org.apache.flink.api.scala.operators
import language.experimental.macros
import scala.reflect.macros.Context
import java.util.{ Iterator => JIterator }
import eu.stratosphere.types.Record
import eu.stratosphere.util.Collector
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.java.record.operators.CoGroupOperator
import eu.stratosphere.api.java.record.functions.{CoGroupFunction => JCoGroupFunction}
import eu.stratosphere.api.common.operators.util.UserCodeObjectWrapper
import eu.stratosphere.configuration.Configuration
import java.util.{ Iterator => JIterator }
import eu.stratosphere.api.scala.codegen.{MacroContextHolder, Util}
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.analysis._
import eu.stratosphere.api.scala.functions.DeserializingIterator
import eu.stratosphere.api.scala.functions.{CoGroupFunctionBase, CoGroupFunction, FlatCoGroupFunction}
import org.apache.flink.api.scala.codegen.{MacroContextHolder, Util}
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.analysis._
import org.apache.flink.api.scala.functions.DeserializingIterator
import org.apache.flink.api.scala.functions.{CoGroupFunctionBase, CoGroupFunction, FlatCoGroupFunction}
import org.apache.flink.api.scala.analysis.FieldSelector
import org.apache.flink.api.scala.DataSet
import org.apache.flink.api.scala.TwoInputHintable
class CoGroupDataSet[LeftIn, RightIn](val leftInput: DataSet[LeftIn], val rightInput: DataSet[RightIn]) {
def where[Key](keyFun: LeftIn => Key): CoGroupDataSetWithWhere[LeftIn, RightIn, Key] = macro CoGroupMacros.whereImpl[LeftIn, RightIn, Key]
......
......@@ -11,22 +11,23 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
package org.apache.flink.api.scala.operators
import scala.language.reflectiveCalls
import eu.stratosphere.api.scala.ScalaOperator
import eu.stratosphere.api.java.record.operators.MapOperator
import eu.stratosphere.api.scala.analysis.UDT
import eu.stratosphere.types.Record
import eu.stratosphere.api.java.record.functions.MapFunction
import org.apache.flink.api.scala.ScalaOperator
import org.apache.flink.api.scala.DataSet
import org.apache.flink.api.scala.OneInputScalaOperator
import org.apache.flink.api.scala.analysis.UDT
import org.apache.flink.api.scala.analysis.UDF1
import org.apache.flink.api.scala.analysis.UDTSerializer
import eu.stratosphere.util.Collector
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.scala.OneInputScalaOperator
import eu.stratosphere.api.scala.analysis.UDF1
import eu.stratosphere.api.scala.analysis.UDTSerializer
import eu.stratosphere.configuration.Configuration
import eu.stratosphere.api.scala.DataSet
import eu.stratosphere.types.Record
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.java.record.functions.MapFunction
import eu.stratosphere.api.java.record.operators.MapOperator
object CopyOperator {
def apply(source: Operator[Record] with ScalaOperator[_, _]): DataSet[_] = {
......
......@@ -11,26 +11,28 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
package org.apache.flink.api.scala.operators
import language.experimental.macros
import scala.reflect.macros.Context
import eu.stratosphere.api.java.record.operators.MapOperator
import java.util.{ Iterator => JIterator }
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.analysis._
import org.apache.flink.api.scala.functions.{CrossFunctionBase, CrossFunction, FlatCrossFunction}
import org.apache.flink.api.scala.codegen.{MacroContextHolder, Util}
import org.apache.flink.api.scala.functions.DeserializingIterator
import org.apache.flink.api.scala.DataSet
import org.apache.flink.api.scala.TwoInputHintable
import eu.stratosphere.api.java.record.operators.MapOperator
import eu.stratosphere.types.Record
import eu.stratosphere.util.Collector
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.java.record.operators.CrossOperator
import eu.stratosphere.configuration.Configuration;
import java.util.{ Iterator => JIterator }
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.analysis._
import eu.stratosphere.api.scala.functions.{CrossFunctionBase, CrossFunction, FlatCrossFunction}
import eu.stratosphere.api.scala.codegen.{MacroContextHolder, Util}
import eu.stratosphere.api.scala.functions.DeserializingIterator
import eu.stratosphere.configuration.Configuration
class CrossDataSet[LeftIn, RightIn](val leftInput: DataSet[LeftIn], val rightInput: DataSet[RightIn]) {
def map[Out](fun: (LeftIn, RightIn) => Out): DataSet[Out] with TwoInputHintable[LeftIn, RightIn, Out] = macro CrossMacros.map[LeftIn, RightIn, Out]
......
......@@ -11,19 +11,22 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
package org.apache.flink.api.scala.operators
import language.experimental.macros
import scala.reflect.macros.Context
import java.io.DataOutput
import java.io.OutputStream
import scala.reflect.macros.Context
import eu.stratosphere.api.scala.ScalaOutputFormat
import eu.stratosphere.api.scala.analysis.{UDTSerializer, UDF1, UDT, InputField}
import eu.stratosphere.configuration.Configuration;
import eu.stratosphere.api.scala.codegen.UDTDescriptors
import eu.stratosphere.api.scala.codegen.MacroContextHolder
import org.apache.flink.api.scala.ScalaOutputFormat
import org.apache.flink.api.scala.analysis.{UDTSerializer, UDT, InputField}
import org.apache.flink.api.scala.analysis.UDF1
import org.apache.flink.api.scala.codegen.UDTDescriptors
import org.apache.flink.api.scala.codegen.MacroContextHolder
import eu.stratosphere.configuration.Configuration
import eu.stratosphere.types.Record
import eu.stratosphere.api.common.io.{BinaryOutputFormat => JavaBinaryOutputFormat}
import eu.stratosphere.api.common.io.{SerializedOutputFormat => JavaSerializedOutputFormat}
......
......@@ -11,12 +11,20 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
package org.apache.flink.api.scala.operators
import java.io.DataInput
import scala.language.experimental.macros
import scala.reflect.macros.Context
import eu.stratosphere.configuration.Configuration;
import java.io.DataInput
import org.apache.flink.api.scala.ScalaInputFormat
import org.apache.flink.api.scala.analysis.{UDTSerializer, OutputField, UDT}
import org.apache.flink.api.scala.analysis.UDF0
import org.apache.flink.api.scala.analysis.OutputField
import org.apache.flink.api.scala.codegen.MacroContextHolder
import eu.stratosphere.configuration.Configuration
import eu.stratosphere.types.Record
import eu.stratosphere.types.Value
import eu.stratosphere.types.DoubleValue
......@@ -28,8 +36,6 @@ import eu.stratosphere.types.parser.DecimalTextIntParser
import eu.stratosphere.types.parser.DecimalTextLongParser
import eu.stratosphere.types.parser.FieldParser
import eu.stratosphere.types.parser.VarLengthStringParser
import eu.stratosphere.api.scala.ScalaInputFormat
import eu.stratosphere.api.scala.analysis.{UDTSerializer, OutputField, UDF0, UDT}
import eu.stratosphere.api.common.io.{InputFormat => JavaInputFormat}
import eu.stratosphere.api.common.io.{BinaryInputFormat => JavaBinaryInputFormat}
import eu.stratosphere.api.common.io.{SerializedInputFormat => JavaSerializedInputFormat}
......@@ -37,7 +43,6 @@ import eu.stratosphere.api.java.record.io.{DelimitedInputFormat => JavaDelimited
import eu.stratosphere.api.java.record.io.{FixedLengthInputFormat => JavaFixedLengthInputFormat}
import eu.stratosphere.api.java.record.io.{CsvInputFormat => JavaCsvInputFormat}
import eu.stratosphere.api.java.record.io.{TextInputFormat => JavaTextInputFormat}
import eu.stratosphere.api.scala.codegen.MacroContextHolder
trait ScalaInputFormatBase[Out] extends ScalaInputFormat[Out] { this: JavaInputFormat[_, _] =>
......
......@@ -11,25 +11,23 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
package org.apache.flink.api.scala.operators
import language.experimental.macros
import scala.reflect.macros.Context
import eu.stratosphere.api.scala.codegen.MacroContextHolder
import eu.stratosphere.api.scala._
import eu.stratosphere.api.java.record.operators.MapOperator
import eu.stratosphere.api.scala.analysis.UDT
import eu.stratosphere.types.Record
import eu.stratosphere.api.java.record.functions.MapFunction
import eu.stratosphere.util.Collector
import eu.stratosphere.api.common.operators.{UnaryOperatorInformation, Operator}
import eu.stratosphere.api.scala.analysis.UDF1
import eu.stratosphere.api.scala.analysis.UDTSerializer
import eu.stratosphere.configuration.Configuration;
import eu.stratosphere.api.scala.analysis.UDF0
import org.apache.flink.api.scala.DataSet
import org.apache.flink.api.scala.codegen.MacroContextHolder
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.analysis.UDT
import org.apache.flink.api.scala.analysis.UDT.NothingUDT
import org.apache.flink.api.scala.analysis.UDF1
import org.apache.flink.api.scala.analysis.UDTSerializer
import org.apache.flink.api.scala.analysis.UDF0
import org.apache.flink.api.scala.analysis.FieldSelector
import eu.stratosphere.configuration.Configuration
import eu.stratosphere.api.common.functions.AbstractFunction
import eu.stratosphere.api.scala.analysis.FieldSelector
import eu.stratosphere.api.scala.analysis.UDT.NothingUDT
import eu.stratosphere.api.java.record.operators.BulkIteration
import eu.stratosphere.api.common.operators.base.BulkIterationBase
import eu.stratosphere.api.java.record.operators.DeltaIteration
......@@ -38,6 +36,11 @@ import eu.stratosphere.api.common.operators.base.MapOperatorBase
import eu.stratosphere.types.NothingTypeInfo
import eu.stratosphere.types.{Nothing => JavaNothing}
import eu.stratosphere.api.java.typeutils.RecordTypeInfo
import eu.stratosphere.api.common.operators.{UnaryOperatorInformation, Operator}
import eu.stratosphere.api.java.record.operators.MapOperator
import eu.stratosphere.types.Record
import eu.stratosphere.api.java.record.functions.MapFunction
import eu.stratosphere.util.Collector
object IterateMacros {
......
......@@ -11,26 +11,28 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
package org.apache.flink.api.scala.operators
import language.experimental.macros
import scala.reflect.macros.Context
import java.util.{ Iterator => JIterator }
import eu.stratosphere.types.Record
import eu.stratosphere.util.Collector
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.java.record.operators.JoinOperator
import eu.stratosphere.api.java.record.functions.{JoinFunction => JJoinFunction}
import eu.stratosphere.api.common.operators.util.UserCodeObjectWrapper
import eu.stratosphere.configuration.Configuration;
import java.util.{ Iterator => JIterator }
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.analysis._
import eu.stratosphere.api.scala.codegen.{MacroContextHolder, Util}
import eu.stratosphere.api.scala.functions.{JoinFunctionBase, JoinFunction, FlatJoinFunction}
import eu.stratosphere.configuration.Configuration
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.analysis._
import org.apache.flink.api.scala.codegen.{MacroContextHolder, Util}
import org.apache.flink.api.scala.functions.{JoinFunctionBase, JoinFunction, FlatJoinFunction}
import org.apache.flink.api.scala.analysis.FieldSelector
import org.apache.flink.api.scala.DataSet
import org.apache.flink.api.scala.TwoInputHintable
class JoinDataSet[LeftIn, RightIn](val leftInput: DataSet[LeftIn], val rightInput: DataSet[RightIn]) {
def where[Key](keyFun: LeftIn => Key) = macro JoinMacros.whereImpl[LeftIn, RightIn, Key]
......
......@@ -11,20 +11,24 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
package org.apache.flink.api.scala.operators
import language.experimental.macros
import scala.reflect.macros.Context
import org.apache.flink.api.scala.codegen.{MacroContextHolder, Util}
import org.apache.flink.api.scala.DataSet
import org.apache.flink.api.scala.OneInputHintable
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.analysis._
import org.apache.flink.api.scala.functions.{MapFunction, MapFunctionBase}
import org.apache.flink.api.scala.functions.{FlatMapFunction, FilterFunction}
import eu.stratosphere.api.java.record.operators.MapOperator
import eu.stratosphere.types.Record
import eu.stratosphere.util.Collector
import eu.stratosphere.api.scala.codegen.{MacroContextHolder, Util}
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.analysis._
import eu.stratosphere.api.scala.functions.{MapFunction, MapFunctionBase}
import eu.stratosphere.api.scala.functions.{FlatMapFunction, FilterFunction}
object MapMacros {
......
......@@ -11,15 +11,24 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
import java.util.{ Iterator => JIterator }
package org.apache.flink.api.scala.operators
import language.experimental.macros
import scala.language.reflectiveCalls
import scala.reflect.macros.Context
import eu.stratosphere.configuration.Configuration;
import java.util.{ Iterator => JIterator }
import org.apache.flink.api.scala.DataSet
import org.apache.flink.api.scala.OneInputHintable
import org.apache.flink.api.scala._
import org.apache.flink.api.scala.analysis._
import org.apache.flink.api.scala.codegen.{MacroContextHolder, Util}
import org.apache.flink.api.scala.functions.{ReduceFunction, ReduceFunctionBase, CombinableGroupReduceFunction, GroupReduceFunction}
import org.apache.flink.api.scala.analysis.UDF1
import org.apache.flink.api.scala.analysis.FieldSelector
import eu.stratosphere.configuration.Configuration
import eu.stratosphere.util.Collector
import eu.stratosphere.api.common.operators.Operator
import eu.stratosphere.api.java.record.operators.MapOperator
......@@ -28,10 +37,6 @@ import eu.stratosphere.types.IntValue
import eu.stratosphere.api.java.record.operators.ReduceOperator
import eu.stratosphere.api.java.record.functions.{ReduceFunction => JReduceFunction}
import eu.stratosphere.api.scala._
import eu.stratosphere.api.scala.analysis._
import eu.stratosphere.api.scala.codegen.{MacroContextHolder, Util}
import eu.stratosphere.api.scala.functions.{ReduceFunction, ReduceFunctionBase, CombinableGroupReduceFunction, GroupReduceFunction}
class KeyedDataSet[In](val keySelection: List[Int], val input: DataSet[In]) {
def reduceGroup[Out](fun: Iterator[In] => Out): DataSet[Out] with OneInputHintable[In, Out] = macro ReduceMacros.reduceGroup[In, Out]
......
......@@ -11,12 +11,14 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala.operators
package org.apache.flink.api.scala.operators
import language.experimental.macros
import eu.stratosphere.api.scala.UnionScalaOperator
import eu.stratosphere.api.scala.DataSet
import eu.stratosphere.api.scala.analysis.UDF2
import org.apache.flink.api.scala.UnionScalaOperator
import org.apache.flink.api.scala.DataSet
import org.apache.flink.api.scala.analysis.UDF2
import eu.stratosphere.api.common.operators.Union
import eu.stratosphere.types.Record
......
......@@ -11,7 +11,7 @@
* specific language governing permissions and limitations under the License.
**********************************************************************************************************************/
package eu.stratosphere.api.scala
package org.apache.flink.api.scala
import scala.language.implicitConversions
......@@ -19,11 +19,6 @@ import scala.collection.TraversableOnce
package object operators {
// implicit def funToRepeat[SolutionItem: UDT](stepFunction: DataStream[SolutionItem] => DataStream[SolutionItem]) = new RepeatOperator(stepFunction)
// implicit def funToIterate[SolutionItem, DeltaItem](s0: DataStream[SolutionItem]) = new IterateOperator(s0.contract)
// implicit def funToWorksetIterate[SolutionItem: UDT, WorksetItem: UDT](stepFunction: (DataStream[SolutionItem], DataStream[WorksetItem]) => (DataStream[SolutionItem], DataStream[WorksetItem])) = new WorksetIterateOperator(stepFunction)
implicit def traversableToIterator[T](i: TraversableOnce[T]): Iterator[T] = i.toIterator
implicit def optionToIterator[T](opt: Option[T]): Iterator[T] = opt.iterator
implicit def arrayToIterator[T](arr: Array[T]): Iterator[T] = arr.iterator
......
/*
/***********************************************************************************************************************
* Copyright (C) 2010-2013 by the Stratosphere project (http://stratosphere.eu)
*
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
......@@ -9,9 +9,9 @@
* Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on
* an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the
* specific language governing permissions and limitations under the License.
*/
**********************************************************************************************************************/
package eu.stratosphere.api.scala
package org.apache.flink.api.scala
import eu.stratosphere.api.java.record.operators.{CollectionDataSource => JCollectionDataSource}
import eu.stratosphere.types.{DoubleValue, Record}
......@@ -19,10 +19,11 @@ import org.scalatest.junit.AssertionsForJUnit
import org.junit.Assert._
import org.junit.Test
class CollectionDataSourceTest extends AssertionsForJUnit {
@Test def testScalaCollectionInput() {
val expected = List(1.0, 2.0, 3.0)
val datasource = CollectionDataSource(expected)
val datasource = org.apache.flink.api.scala.CollectionDataSource(expected)
val javaCDS = datasource.contract.asInstanceOf[JCollectionDataSource]
......
......@@ -13,9 +13,10 @@
package eu.stratosphere.test.exampleScalaPrograms;
import org.apache.flink.examples.scala.graph.ComputeEdgeDegrees;
import eu.stratosphere.api.common.Plan;
import eu.stratosphere.configuration.Configuration;
import eu.stratosphere.examples.scala.graph.ComputeEdgeDegrees;
public class ComputeEdgeDegreesITCase extends eu.stratosphere.test.recordJobTests.ComputeEdgeDegreesITCase {
......
......@@ -13,8 +13,9 @@
package eu.stratosphere.test.exampleScalaPrograms;
import org.apache.flink.examples.scala.graph.ConnectedComponents;
import eu.stratosphere.api.common.Plan;
import eu.stratosphere.examples.scala.graph.ConnectedComponents;
public class ConnectedComponentsITCase extends eu.stratosphere.test.iterative.ConnectedComponentsITCase {
......
......@@ -13,9 +13,10 @@
package eu.stratosphere.test.exampleScalaPrograms;
import org.apache.flink.examples.scala.graph.EnumTrianglesOnEdgesWithDegrees;
import eu.stratosphere.api.common.Plan;
import eu.stratosphere.configuration.Configuration;
import eu.stratosphere.examples.scala.graph.EnumTrianglesOnEdgesWithDegrees;
public class EnumTrianglesOnEdgesWithDegreesITCase extends eu.stratosphere.test.recordJobTests.EnumTrianglesOnEdgesWithDegreesITCase {
......
......@@ -15,8 +15,9 @@ package eu.stratosphere.test.exampleScalaPrograms;
import java.util.Locale;
import org.apache.flink.examples.scala.datamining.KMeans;
import eu.stratosphere.api.common.Plan;
import eu.stratosphere.examples.scala.datamining.KMeans;
import eu.stratosphere.test.testdata.KMeansData;
import eu.stratosphere.test.util.RecordAPITestBase;
......
......@@ -13,12 +13,12 @@
package eu.stratosphere.test.exampleScalaPrograms;
import org.apache.flink.examples.scala.relational.RelationalQuery;
import org.junit.runner.RunWith;
import org.junit.runners.Parameterized;
import eu.stratosphere.api.common.Plan;
import eu.stratosphere.configuration.Configuration;
import eu.stratosphere.examples.scala.relational.RelationalQuery;
import java.util.Locale;
......
......@@ -13,11 +13,11 @@
package eu.stratosphere.test.exampleScalaPrograms;
import org.apache.flink.examples.scala.graph.TransitiveClosureNaive;
import eu.stratosphere.api.common.Plan;
import eu.stratosphere.test.util.RecordAPITestBase;
import eu.stratosphere.examples.scala.graph.TransitiveClosureNaive;
public class TransitiveClosureNaiveITCase extends RecordAPITestBase {
protected String verticesPath = null;
......
......@@ -13,8 +13,9 @@
package eu.stratosphere.test.exampleScalaPrograms;
import org.apache.flink.examples.scala.relational.WebLogAnalysis;
import eu.stratosphere.api.common.Plan;
import eu.stratosphere.examples.scala.relational.WebLogAnalysis;
public class WebLogAnalysisITCase extends eu.stratosphere.test.recordJobTests.WebLogAnalysisITCase {
......
......@@ -13,9 +13,9 @@
package eu.stratosphere.test.exampleScalaPrograms;
import eu.stratosphere.api.common.Plan;
import org.apache.flink.examples.scala.wordcount.WordCount;
import eu.stratosphere.examples.scala.wordcount.WordCount;
import eu.stratosphere.api.common.Plan;
public class WordCountITCase extends eu.stratosphere.test.recordJobTests.WordCountITCase {
......
......@@ -13,8 +13,9 @@
package eu.stratosphere.test.exampleScalaPrograms;
import org.apache.flink.examples.scala.wordcount.WordCountWithUserDefinedType;
import eu.stratosphere.api.common.Plan;
import eu.stratosphere.examples.scala.wordcount.WordCountWithUserDefinedType;
public class WordCountPactValueITCase extends eu.stratosphere.test.recordJobTests.WordCountITCase {
......
......@@ -13,8 +13,9 @@
package eu.stratosphere.test.exampleScalaPrograms;
import org.apache.flink.examples.scala.wordcount.WordCountWithCount;
import eu.stratosphere.api.common.Plan;
import eu.stratosphere.examples.scala.wordcount.WordCountWithCount;
public class WordCountWithCountFunctionITCase extends eu.stratosphere.test.recordJobTests.WordCountITCase {
......
......@@ -16,13 +16,14 @@ package eu.stratosphere.test.iterative;
import java.util.Collection;
import eu.stratosphere.test.util.RecordAPITestBase;
import org.apache.flink.examples.scala.graph.LineRank;
import org.junit.runner.RunWith;
import org.junit.runners.Parameterized;
import org.junit.runners.Parameterized.Parameters;
import eu.stratosphere.api.common.Plan;
import eu.stratosphere.configuration.Configuration;
import eu.stratosphere.examples.scala.graph.LineRank;
@RunWith(Parameterized.class)
public class LineRankITCase extends RecordAPITestBase {
......
Markdown is supported
0% .
You are about to add 0 people to the discussion. Proceed with caution.
先完成此消息的编辑!
想要评论请 注册