Package org.apache.spark.api.java.function


package org.apache.spark.api.java.function
Set of interfaces to represent functions in Spark's Java API. Users create implementations of these interfaces to pass functions to various Java API methods for Spark. Please visit Spark's Java programming guide for more details.
  • Interfaces
    Class
    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.
    A function that returns zero or more records of type Double from each input record.
    A function that returns Doubles, and can be used to construct DoubleRDDs.
    Base interface for a function used in Dataset's filter function.
    A function that returns zero or more output records from each input record.
    A function that takes two inputs and returns zero or more output records.
    A function that returns zero or more output records from each grouping key and its values.
    ::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)
    Base interface for a function used in Dataset's foreach function.
    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.
    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.
    Base interface for a map function used in Dataset's map function.
    Base interface for a map function used in GroupedDataset's mapGroup function.
    Base interface for function used in Dataset's mapPartitions.
    A function that returns zero or more key-value pair records from each input record.
    A function that returns key-value pairs (Tuple2<K, V>), and can be used to construct PairRDDs.
    Base interface for function used in Dataset's reduce.
    A function with no return value.
    A two-argument function that takes arguments of type T1 and T2 with no return value.