Interface | Description |
---|---|
AggregateFunction<IN,ACC,OUT> |
The
AggregateFunction is a flexible aggregation function, characterized by the
following features:
The aggregates may use different types for input values, intermediate aggregates,
and result type, to support a wide range of aggregation types.
Support for distributive aggregations: Different intermediate aggregates can be
merged together, to allow for pre-aggregation/final-aggregation optimizations.
|
BroadcastVariableInitializer<T,O> |
A broadcast variable initializer can be used to transform a broadcast variable
into another format during initialization.
|
CoGroupFunction<IN1,IN2,O> |
The interface for CoGroup functions.
|
CombineFunction<IN,OUT> |
Generic interface used for combine functions ("combiners").
|
CrossFunction<IN1,IN2,OUT> |
Interface for Cross functions.
|
FilterFunction<T> |
A filter function is a predicate applied individually to each record.
|
FlatJoinFunction<IN1,IN2,OUT> |
Interface for Join functions.
|
FlatMapFunction<T,O> |
Base interface for flatMap functions.
|
FoldFunction<O,T> | Deprecated
use
AggregateFunction instead |
Function |
The base interface for all user-defined functions.
|
GroupCombineFunction<IN,OUT> |
Generic interface used for combine functions ("combiners").
|
GroupReduceFunction<T,O> |
The interface for group reduce functions.
|
IterationRuntimeContext | |
JoinFunction<IN1,IN2,OUT> |
Interface for Join functions.
|
MapFunction<T,O> |
Base interface for Map functions.
|
MapPartitionFunction<T,O> |
Interface for "mapPartition" functions.
|
Partitioner<K> |
Function to implement a custom partition assignment for keys.
|
ReduceFunction<T> |
Base interface for Reduce functions.
|
RichFunction |
An base interface for all rich user-defined functions.
|
RuntimeContext |
A RuntimeContext contains information about the context in which functions are executed.
|
StoppableFunction |
Must be implemented by stoppable functions, eg, source functions of streaming jobs.
|
Class | Description |
---|---|
AbstractRichFunction |
An abstract stub implementation for rich user-defined functions.
|
RichAggregateFunction<IN,ACC,OUT> |
Rich variant of the
AggregateFunction . |
RichCoGroupFunction<IN1,IN2,OUT> |
Rich variant of the
CoGroupFunction . |
RichCrossFunction<IN1,IN2,OUT> |
Rich variant of the
CrossFunction . |
RichFilterFunction<T> |
Rich variant of the
FilterFunction . |
RichFlatJoinFunction<IN1,IN2,OUT> |
Rich variant of the
FlatJoinFunction . |
RichFlatMapFunction<IN,OUT> |
Rich variant of the
FlatMapFunction . |
RichFoldFunction<O,T> | Deprecated
use
RichAggregateFunction instead |
RichGroupCombineFunction<IN,OUT> |
Rich variant of the
GroupCombineFunction . |
RichGroupReduceFunction<IN,OUT> |
Rich variant of the
GroupReduceFunction . |
RichJoinFunction<IN1,IN2,OUT> |
Rich variant of the
JoinFunction . |
RichMapFunction<IN,OUT> |
Rich variant of the
MapFunction . |
RichMapPartitionFunction<I,O> |
Rich variant of the
MapPartitionFunction . |
RichReduceFunction<T> |
Rich variant of the
ReduceFunction . |
Exception | Description |
---|---|
InvalidTypesException |
A special case of the
InvalidProgramException , indicating that the types used in
an operation are invalid or inconsistent. |
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.