org.apache.flink.api

scala

package scala

The Flink Scala API. org.apache.flink.api.scala.ExecutionEnvironment is the starting-point of any Flink program. It can be used to read from local files, HDFS, or other sources. org.apache.flink.api.scala.DataSet is the main abstraction of data in Flink. It provides operations that create new DataSets via transformations. org.apache.flink.api.scala.GroupedDataSet provides operations on grouped data that results from org.apache.flink.api.scala.DataSet.groupBy().

Use org.apache.flink.api.scala.ExecutionEnvironment.getExecutionEnvironment to obtain an execution environment. This will either create a local environment or a remote environment, depending on the context where your program is executing.

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. scala
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

  1. class AggregateDataSet[T] extends DataSet[T]

    The result of DataSet.aggregate.

  2. class CoGroupDataSet[L, R] extends DataSet[(Array[L], Array[R])]

    A specific DataSet that results from a coGroup operation.

  3. class CrossDataSet[L, R] extends DataSet[(L, R)]

    A specific DataSet that results from a cross operation.

  4. class DataSet[T] extends AnyRef

    The DataSet, the basic abstraction of Flink.

  5. class ExecutionEnvironment extends AnyRef

    The ExecutionEnvironment is the context in which a program is executed.

  6. class GroupedDataSet[T] extends AnyRef

    A DataSet to which a grouping key was added.

  7. class JoinDataSet[L, R] extends DataSet[(L, R)] with JoinFunctionAssigner[L, R]

    A specific DataSet that results from a join operation.

  8. trait JoinFunctionAssigner[L, R] extends AnyRef

    Annotations
    @Public()
  9. class PartitionSortedDataSet[T] extends DataSet[T]

    The result of DataSet.sortPartition.

  10. class SelectByMaxFunction[T] extends ReduceFunction[T]

    SelectByMaxFunction to work with Scala tuples

  11. class SelectByMinFunction[T] extends ReduceFunction[T]

    SelectByMinFunction to work with Scala tuples

  12. class Tuple2CaseClassSerializer[T1, T2] extends CaseClassSerializer[(T1, T2)]

  13. class UnfinishedCoGroupOperation[L, R] extends UnfinishedKeyPairOperation[L, R, CoGroupDataSet[L, R]]

    An unfinished coGroup operation that results from DataSet.coGroup The keys for the left and right side must be specified using first where and then equalTo.

  14. class UnfinishedJoinOperation[L, R] extends UnfinishedJoinOperationBase[L, R, JoinDataSet[L, R]]

    An unfinished inner join operation that results from calling DataSet.join().

  15. class UnfinishedOuterJoinOperation[L, R] extends UnfinishedJoinOperationBase[L, R, JoinFunctionAssigner[L, R]]

    An unfinished outer join operation that results from calling, e.

Value Members

  1. object ClosureCleaner

    Annotations
    @Internal()
  2. object ExecutionEnvironment

    Annotations
    @Public()
  3. def createTuple2TypeInformation[T1, T2](t1: TypeInformation[T1], t2: TypeInformation[T2]): TypeInformation[(T1, T2)]

  4. implicit def createTypeInformation[T]: TypeInformation[T]

    Annotations
    @macroImpl( ... )
  5. package extensions

    acceptPartialFunctions extends the original DataSet with methods with unique names that delegate to core higher-order functions (e.

  6. def getCallLocationName(depth: Int = 3): String

  7. package hadoop

  8. package metrics

  9. package operators

  10. implicit val scalaNothingTypeInfo: TypeInformation[Nothing]

  11. package typeutils

  12. package utils

Inherited from AnyRef

Inherited from Any

Ungrouped