See: Description
| Interface | Description |
|---|---|
| CoGroupFunction<K,V1,V2,R> |
A function that returns zero or more output records from each grouping key and its values from 2
Datasets.
|
| DoubleFlatMapFunction<T> |
A function that returns zero or more records of type Double from each input record.
|
| DoubleFunction<T> |
A function that returns Doubles, and can be used to construct DoubleRDDs.
|
| FilterFunction<T> |
Base interface for a function used in Dataset's filter function.
|
| FlatMapFunction<T,R> |
A function that returns zero or more output records from each input record.
|
| FlatMapFunction2<T1,T2,R> |
A function that takes two inputs and returns zero or more output records.
|
| FlatMapGroupsFunction<K,V,R> |
A function that returns zero or more output records from each grouping key and its values.
|
| FlatMapGroupsWithStateFunction<K,V,S,R> |
::Experimental::
Base interface for a map function used in
org.apache.spark.sql.KeyValueGroupedDataset.flatMapGroupsWithState(
FlatMapGroupsWithStateFunction, org.apache.spark.sql.streaming.OutputMode,
org.apache.spark.sql.Encoder, org.apache.spark.sql.Encoder) |
| ForeachFunction<T> |
Base interface for a function used in Dataset's foreach function.
|
| ForeachPartitionFunction<T> |
Base interface for a function used in Dataset's foreachPartition function.
|
| Function<T1,R> |
Base interface for functions whose return types do not create special RDDs.
|
| Function0<R> |
A zero-argument function that returns an R.
|
| Function2<T1,T2,R> |
A two-argument function that takes arguments of type T1 and T2 and returns an R.
|
| Function3<T1,T2,T3,R> |
A three-argument function that takes arguments of type T1, T2 and T3 and returns an R.
|
| Function4<T1,T2,T3,T4,R> |
A four-argument function that takes arguments of type T1, T2, T3 and T4 and returns an R.
|
| MapFunction<T,U> |
Base interface for a map function used in Dataset's map function.
|
| MapGroupsFunction<K,V,R> |
Base interface for a map function used in GroupedDataset's mapGroup function.
|
| MapGroupsWithStateFunction<K,V,S,R> |
::Experimental::
Base interface for a map function used in
KeyValueGroupedDataset.mapGroupsWithState(
MapGroupsWithStateFunction, org.apache.spark.sql.Encoder, org.apache.spark.sql.Encoder) |
| MapPartitionsFunction<T,U> |
Base interface for function used in Dataset's mapPartitions.
|
| PairFlatMapFunction<T,K,V> |
A function that returns zero or more key-value pair records from each input record.
|
| PairFunction<T,K,V> |
A function that returns key-value pairs (Tuple2<K, V>), and can be used to
construct PairRDDs.
|
| ReduceFunction<T> |
Base interface for function used in Dataset's reduce.
|
| VoidFunction<T> |
A function with no return value.
|
| VoidFunction2<T1,T2> |
A two-argument function that takes arguments of type T1 and T2 with no return value.
|