Interface | Description |
---|---|
Driver<S extends Function,OT> |
The interface to be implemented by all drivers that run alone (or as the primary driver) in a task.
|
ResettableDriver<S extends Function,OT> |
This interface marks a
Driver as resettable, meaning that will reset part of their internal state but
otherwise reuse existing data structures. |
TaskContext<S,OT> |
The task context gives a driver (e.g.,
MapDriver , or JoinDriver ) access to
the runtime components and configuration that they can use to fulfil their task. |
Class | Description |
---|---|
AbstractCachedBuildSideJoinDriver<IT1,IT2,OT> | |
AbstractOuterJoinDriver<IT1,IT2,OT> |
The abstract outer join driver implements the logic of an outer join operator at runtime.
|
AllGroupCombineDriver<IN,OUT> |
Non-chained driver for the partial group reduce operator that acts like a combiner with a custom output type OUT.
|
AllGroupReduceDriver<IT,OT> |
GroupReduceDriver task which is executed by a Task Manager.
|
AllReduceDriver<T> |
Reduce task which is executed by a Task Manager.
|
BatchTask<S extends Function,OT> |
The base class for all batch tasks.
|
BuildFirstCachedJoinDriver<IT1,IT2,OT> | |
BuildSecondCachedJoinDriver<IT1,IT2,OT> | |
CoGroupDriver<IT1,IT2,OT> |
CoGroup task which is executed by a Task Manager.
|
CoGroupRawDriver<IT1,IT2,OT> | |
CoGroupRawDriver.SimpleIterable<IN> | |
CoGroupWithSolutionSetFirstDriver<IT1,IT2,OT> | |
CoGroupWithSolutionSetSecondDriver<IT1,IT2,OT> | |
CrossDriver<T1,T2,OT> |
Cross task which is executed by a Task Manager.
|
DataSinkTask<IT> |
DataSinkTask which is executed by a task manager.
|
DataSourceTask<OT> |
DataSourceTask which is executed by a task manager.
|
FlatMapDriver<IT,OT> |
Map task which is executed by a Task Manager.
|
FullOuterJoinDriver<IT1,IT2,OT> |
The full outer join driver implements the logic of an outer join operator at runtime.
|
GroupReduceCombineDriver<IN,OUT> |
Non-chained combine driver which is used for a CombineGroup transformation or a GroupReduce transformation where
the user supplied a RichGroupReduceFunction with a combine method.
|
GroupReduceDriver<IT,OT> |
GroupReduce task which is executed by a Task Manager.
|
JoinDriver<IT1,IT2,OT> |
The join driver implements the logic of a join operator at runtime.
|
JoinWithSolutionSetFirstDriver<IT1,IT2,OT> | |
JoinWithSolutionSetSecondDriver<IT1,IT2,OT> | |
LeftOuterJoinDriver<IT1,IT2,OT> |
The left outer join driver implements the logic of an outer join operator at runtime.
|
MapDriver<IT,OT> |
Map task which is executed by a Task Manager.
|
MapPartitionDriver<IT,OT> |
MapPartition task which is executed by a Task Manager.
|
NoOpChainedDriver<IT> |
A chained driver that just passes on the input as the output
|
NoOpDriver<T> |
A driver that does nothing but forward data from its input to its output.
|
ReduceCombineDriver<T> |
Combine operator for Reduce functions, standalone (not chained).
|
ReduceDriver<T> |
Reduce driver which is executed by a Task Manager.
|
RightOuterJoinDriver<IT1,IT2,OT> |
The right outer join driver implements the logic of an outer join operator at runtime.
|
TempBarrier<T> | |
UnionWithTempOperator<T> |
Enum | Description |
---|---|
DamBehavior |
Enumeration for the different dam behaviors of an algorithm or a driver
strategy.
|
DriverStrategy |
Enumeration of all available operator strategies.
|
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.