Modifier and Type | Class and Description |
---|---|
interface |
Experimental
Annotation to mark classes for experimental use.
|
interface |
Internal
Annotation to mark methods within stable, public APIs as an internal developer API.
|
interface |
Public
Annotation for marking classes as public, stable interfaces.
|
interface |
PublicEvolving
Annotation to mark classes and methods for public use, but with evolving interfaces.
|
Modifier and Type | Class and Description |
---|---|
class |
ExecutionConfig
A config to define the behavior of the program execution.
|
class |
ExecutionMode
The execution mode specifies how a batch program is executed in terms of data exchange:
pipelining or batched.
|
class |
InvalidProgramException
An exception thrown to indicate that the composed program is invalid.
|
class |
JobExecutionResult
The result of a job execution.
|
class |
JobID
Unique (at least statistically unique) identifier for a Flink Job.
|
class |
JobSubmissionResult
The result of submitting a job to a JobManager.
|
class |
NonSerializableUserCodeException
An special case of the
InvalidProgramException , indicating that a part of the program
that needs to be serializable (for shipping) is not serializable. |
Modifier and Type | Interface and Description |
---|---|
interface |
Accumulator<V,R extends Serializable>
Accumulators collect distributed statistics or aggregates in a from user functions and operators.
|
class |
AverageAccumulator
An accumulator that computes the average value.
|
class |
Histogram
Histogram accumulator, which builds a histogram in a distributed manner.
|
class |
ListAccumulator<T>
This accumulator stores a collection of objects.
|
interface |
SimpleAccumulator<T extends Serializable>
Similar to Accumulator, but the type of items to add and the result value must be the same.
|
Modifier and Type | Class and Description |
---|---|
class |
DistributedCache
DistributedCache provides static methods to write the registered cache files into job
configuration or decode them from job configuration.
|
Modifier and Type | Class and Description |
---|---|
class |
AscendingTimestampsWatermarks<T>
A watermark generator that assumes monotonically ascending timestamps within the stream split and
periodically generates watermarks based on that assumption.
|
class |
BoundedOutOfOrdernessWatermarks<T>
A WatermarkGenerator for situations where records are out of order, but you can place an upper
bound on how far the events are out of order.
|
class |
IngestionTimeAssigner<T>
A timestamp assigner that assigns timestamps based on the machine's wall clock.
|
class |
NoWatermarksGenerator<E>
An implementation of a
WatermarkGenerator that generates no Watermarks. |
class |
RecordTimestampAssigner<E>
A
TimestampAssigner that forwards the already-assigned timestamp. |
interface |
TimestampAssigner<T>
A
TimestampAssigner assigns event time timestamps to elements. |
class |
Watermark
Watermarks are the progress indicators in the data streams.
|
interface |
WatermarkGenerator<T>
The
WatermarkGenerator generates watermarks either based on events or periodically (in a
fixed interval). |
interface |
WatermarkOutput
An output for watermarks.
|
interface |
WatermarkStrategy<T>
The WatermarkStrategy defines how to generate
Watermark s in the stream sources. |
class |
WatermarksWithIdleness<T>
A WatermarkGenerator that adds idleness detection to another WatermarkGenerator.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractRichFunction
An abstract stub implementation for rich user-defined functions.
|
interface |
BroadcastVariableInitializer<T,O>
A broadcast variable initializer can be used to transform a broadcast variable into another
format during initialization.
|
interface |
CoGroupFunction<IN1,IN2,O>
The interface for CoGroup functions.
|
interface |
CombineFunction<IN,OUT>
Generic interface used for combine functions ("combiners").
|
interface |
CrossFunction<IN1,IN2,OUT>
Interface for Cross functions.
|
interface |
FilterFunction<T>
A filter function is a predicate applied individually to each record.
|
interface |
FlatJoinFunction<IN1,IN2,OUT>
Interface for Join functions.
|
interface |
FlatMapFunction<T,O>
Base interface for flatMap functions.
|
interface |
FoldFunction<O,T>
Deprecated.
use
AggregateFunction instead |
interface |
Function
The base interface for all user-defined functions.
|
interface |
GroupCombineFunction<IN,OUT>
Generic interface used for combine functions ("combiners").
|
interface |
GroupReduceFunction<T,O>
The interface for group reduce functions.
|
class |
InvalidTypesException
A special case of the
InvalidProgramException , indicating that the types used in an
operation are invalid or inconsistent. |
interface |
IterationRuntimeContext
A specialization of the
RuntimeContext available in iterative computations of the DataSet
API. |
interface |
JoinFunction<IN1,IN2,OUT>
Interface for Join functions.
|
interface |
MapFunction<T,O>
Base interface for Map functions.
|
interface |
MapPartitionFunction<T,O>
Interface for "mapPartition" functions.
|
interface |
Partitioner<K>
Function to implement a custom partition assignment for keys.
|
interface |
ReduceFunction<T>
Base interface for Reduce functions.
|
class |
RichCoGroupFunction<IN1,IN2,OUT>
Rich variant of the
CoGroupFunction . |
class |
RichCrossFunction<IN1,IN2,OUT>
Rich variant of the
CrossFunction . |
class |
RichFilterFunction<T>
Rich variant of the
FilterFunction . |
class |
RichFlatJoinFunction<IN1,IN2,OUT>
Rich variant of the
FlatJoinFunction . |
class |
RichFlatMapFunction<IN,OUT>
Rich variant of the
FlatMapFunction . |
class |
RichFoldFunction<O,T>
Deprecated.
use
RichAggregateFunction instead |
interface |
RichFunction
An base interface for all rich user-defined functions.
|
class |
RichGroupCombineFunction<IN,OUT>
Rich variant of the
GroupCombineFunction . |
class |
RichGroupReduceFunction<IN,OUT>
Rich variant of the
GroupReduceFunction . |
class |
RichJoinFunction<IN1,IN2,OUT>
Rich variant of the
JoinFunction . |
class |
RichMapFunction<IN,OUT>
Rich variant of the
MapFunction . |
class |
RichMapPartitionFunction<I,O>
Rich variant of the
MapPartitionFunction . |
class |
RichReduceFunction<T>
Rich variant of the
ReduceFunction . |
interface |
RuntimeContext
A RuntimeContext contains information about the context in which functions are executed.
|
Modifier and Type | Class and Description |
---|---|
class |
BinaryInputFormat<T>
Base class for all input formats that use blocks of fixed size.
|
class |
BinaryOutputFormat<T> |
class |
BlockInfo
A block of 24 bytes written at the end of a block in a binary file, and containing i) the
number of records in the block, ii) the accumulated number of records, and iii) the offset of the
first record in the block.
|
interface |
CleanupWhenUnsuccessful
OutputFormat s may implement this interface to run a cleanup hook when the execution is
not successful. |
class |
DelimitedInputFormat<OT>
Base implementation for input formats that split the input at a delimiter into records.
|
class |
FileInputFormat<OT>
The base class for
RichInputFormat s that read from files. |
class |
FileOutputFormat<IT>
The abstract base class for all Rich output formats that are file based.
|
interface |
FinalizeOnMaster
This interface may be implemented by
OutputFormat s to have the master finalize them
globally. |
class |
GenericInputFormat<OT>
Generic base class for all Rich inputs that are not based on files.
|
interface |
InitializeOnMaster
This interface may be implemented by
OutputFormat s to have the master initialize them
globally. |
interface |
InputFormat<OT,T extends InputSplit>
The base interface for data sources that produces records.
|
class |
InputStreamFSInputWrapper
This class wraps an
InputStream and exposes it as FSDataInputStream . |
class |
LocatableInputSplitAssigner
The locatable input split assigner assigns to each host splits that are local, before assigning
splits that are not local.
|
interface |
NonParallelInput
This interface acts as a marker for input formats for inputs which cannot be split.
|
interface |
OutputFormat<IT>
The base interface for outputs that consumes records.
|
class |
RichInputFormat<OT,T extends InputSplit>
An abstract stub implementation for Rich input formats.
|
class |
RichOutputFormat<IT>
An abstract stub implementation for Rich output formats.
|
class |
SerializedInputFormat<T extends IOReadableWritable>
Reads elements by deserializing them with their regular serialization/deserialization
functionality.
|
class |
SerializedOutputFormat<T extends IOReadableWritable>
Stores elements by serializing them with their regular serialization/deserialization
functionality.
|
Modifier and Type | Interface and Description |
---|---|
interface |
BaseStatistics
Interface describing the basic statistics that can be obtained from the input.
|
Modifier and Type | Class and Description |
---|---|
class |
Order
Enumeration representing order.
|
Modifier and Type | Class and Description |
---|---|
static class |
CrossOperatorBase.CrossHint
The cross hint tells the system which sizes to expect from the data sets
|
static class |
JoinOperatorBase.JoinHint
An enumeration of hints, optionally usable to tell the system how exactly execute the join.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DeserializationSchema<T>
The deserialization schema describes how to turn the byte messages delivered by certain data
sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by
Flink.
|
interface |
SerializationSchema<T>
The serialization schema describes how to turn a data object into a different serialized
representation.
|
class |
TypeInformationSerializationSchema<T>
A serialization and deserialization schema that uses Flink's serialization stack to transform
typed from and to byte arrays.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AtomicType<T>
An atomic type is a type that is treated as one indivisible unit and where the entire type acts
as a key.
|
class |
BasicArrayTypeInfo<T,C>
Type information for arrays boxed primitive types.
|
class |
BasicTypeInfo<T>
Type information for primitive types (int, long, double, byte, ...), String, Date, Void,
BigInteger, and BigDecimal.
|
class |
FractionalTypeInfo<T>
Type information for numeric fractional primitive types (double, float).
|
class |
IntegerTypeInfo<T>
Type information for numeric integer primitive types: int, long, byte, short, character.
|
class |
NothingTypeInfo
Placeholder type information for the
Nothing type. |
class |
NumericTypeInfo<T>
Type information for numeric primitive types: int, long, double, byte, short, float, char.
|
class |
PrimitiveArrayTypeInfo<T>
A
TypeInformation for arrays of primitive types (int, long, double, ...). |
class |
TypeHint<T>
A utility class for describing generic types.
|
interface |
TypeInfo
Annotation for specifying a corresponding
TypeInfoFactory that can produce TypeInformation for the annotated type. |
class |
TypeInfoFactory<T>
Base class for implementing a type information factory.
|
class |
TypeInformation<T>
TypeInformation is the core class of Flink's type system.
|
Modifier and Type | Class and Description |
---|---|
class |
CompositeType<T>
Base type information class for Tuple and Pojo types
|
Modifier and Type | Class and Description |
---|---|
class |
DataSet<T>
A DataSet represents a collection of elements of the same type.
|
class |
ExecutionEnvironment
The ExecutionEnvironment is the context in which a program is executed.
|
interface |
ExecutionEnvironmentFactory
Factory class for execution environments.
|
class |
LocalEnvironment
An
ExecutionEnvironment that runs the program locally, multi-threaded, in the JVM where
the environment is instantiated. |
class |
RemoteEnvironment
An
ExecutionEnvironment that sends programs to a cluster for execution. |
Modifier and Type | Class and Description |
---|---|
class |
Aggregations
Shortcuts for Aggregation factories.
|
Modifier and Type | Class and Description |
---|---|
class |
FunctionAnnotation
This class defines Java annotations for semantic assertions that can be added to Flink functions.
|
interface |
KeySelector<IN,KEY>
The
KeySelector allows to use deterministic objects for operations such as reduce,
reduceGroup, join, coGroup, etc. |
Modifier and Type | Class and Description |
---|---|
class |
HadoopInputFormat<K,V>
Wrapper for using HadoopInputFormats (mapred-variant) with Flink.
|
class |
HadoopOutputFormat<K,V>
Wrapper for using HadoopOutputFormats (mapred-variant) with Flink.
|
Modifier and Type | Class and Description |
---|---|
class |
HadoopInputFormat<K,V>
InputFormat implementation allowing to use Hadoop (mapreduce) InputFormats with Flink.
|
class |
HadoopOutputFormat<K,V>
OutputFormat implementation allowing to use Hadoop (mapreduce) OutputFormats with Flink.
|
Modifier and Type | Class and Description |
---|---|
class |
CsvReader
A builder class to instantiate a CSV parsing data source.
|
class |
DiscardingOutputFormat<T>
An output format that simply discards all elements.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregateOperator<IN>
This operator represents the application of a "aggregate" operation on a data set, and the result
data set produced by the function.
|
class |
CoGroupOperator<I1,I2,OUT>
A
DataSet that is the result of a CoGroup transformation. |
class |
CrossOperator<I1,I2,OUT>
A
DataSet that is the result of a Cross transformation. |
static class |
CrossOperator.DefaultCross<I1,I2>
A Cross transformation that wraps pairs of crossed elements into
Tuple2 . |
static class |
CrossOperator.ProjectCross<I1,I2,OUT extends Tuple>
|
interface |
CustomUnaryOperation<IN,OUT> |
class |
DataSink<T>
An operation that allows storing data results.
|
class |
DataSource<OUT>
An operation that creates a new data set (data source).
|
class |
DeltaIteration<ST,WT>
The DeltaIteration represents the start of a delta iteration.
|
static class |
DeltaIteration.SolutionSetPlaceHolder<ST>
A
DataSet that acts as a placeholder for the solution set during the iteration. |
static class |
DeltaIteration.WorksetPlaceHolder<WT>
A
DataSet that acts as a placeholder for the workset during the iteration. |
class |
DeltaIterationResultSet<ST,WT>
Resulting
DataSet of a delta iteration operation. |
class |
DistinctOperator<T>
This operator represents the application of a "distinct" function on a data set, and the result
data set produced by the function.
|
class |
FilterOperator<T>
This operator represents the application of a "filter" function on a data set, and the result
data set produced by the function.
|
class |
FlatMapOperator<IN,OUT>
This operator represents the application of a "flatMap" function on a data set, and the result
data set produced by the function.
|
class |
GroupCombineOperator<IN,OUT>
This operator behaves like the GroupReduceOperator with Combine but only runs the Combine part
which reduces all data locally in their partitions.
|
class |
Grouping<T>
Grouping is an intermediate step for a transformation on a grouped DataSet.
|
class |
GroupReduceOperator<IN,OUT>
This operator represents the application of a "reduceGroup" function on a data set, and the
result data set produced by the function.
|
class |
IterativeDataSet<T>
The IterativeDataSet represents the start of an iteration.
|
class |
JoinOperator<I1,I2,OUT>
A
DataSet that is the result of a Join transformation. |
static class |
JoinOperator.DefaultJoin<I1,I2>
A Join transformation that wraps pairs of joining elements into
Tuple2 . |
static class |
JoinOperator.EquiJoin<I1,I2,OUT>
A Join transformation that applies a
JoinFunction on each pair of joining elements. |
static class |
JoinOperator.JoinOperatorSets<I1,I2>
Intermediate step of a Join transformation.
|
class |
JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
Intermediate step of a Join transformation.
|
static class |
JoinOperator.ProjectJoin<I1,I2,OUT extends Tuple>
|
class |
MapOperator<IN,OUT>
This operator represents the application of a "map" function on a data set, and the result data
set produced by the function.
|
class |
MapPartitionOperator<IN,OUT>
This operator represents the application of a "mapPartition" function on a data set, and the
result data set produced by the function.
|
class |
Operator<OUT,O extends Operator<OUT,O>>
Base class of all operators in the Java API.
|
class |
PartitionOperator<T>
This operator represents a partitioning.
|
class |
ProjectOperator<IN,OUT extends Tuple>
This operator represents the application of a projection operation on a data set, and the result
data set produced by the function.
|
class |
ReduceOperator<IN>
This operator represents the application of a "reduce" function on a data set, and the result
data set produced by the function.
|
class |
SingleInputOperator<IN,OUT,O extends SingleInputOperator<IN,OUT,O>>
Base class for operations that operates on a single input data set.
|
class |
SingleInputUdfOperator<IN,OUT,O extends SingleInputUdfOperator<IN,OUT,O>>
The SingleInputUdfOperator is the base class of all unary operators that execute
user-defined functions (UDFs).
|
class |
SortedGrouping<T>
SortedGrouping is an intermediate step for a transformation on a grouped and sorted DataSet.
|
class |
SortPartitionOperator<T>
This operator represents a DataSet with locally sorted partitions.
|
class |
TwoInputOperator<IN1,IN2,OUT,O extends TwoInputOperator<IN1,IN2,OUT,O>>
Base class for operations that operates on two input data sets.
|
class |
TwoInputUdfOperator<IN1,IN2,OUT,O extends TwoInputUdfOperator<IN1,IN2,OUT,O>>
The TwoInputUdfOperator is the base class of all binary operators that execute
user-defined functions (UDFs).
|
interface |
UdfOperator<O extends UdfOperator<O>>
This interface marks operators as operators that execute user-defined functions (UDFs), such as
RichMapFunction , RichReduceFunction , or RichCoGroupFunction . |
class |
UnionOperator<T>
Java API operator for union of two data sets.
|
class |
UnsortedGrouping<T>
A
Grouping that is unsorted. |
Modifier and Type | Interface and Description |
---|---|
interface |
JoinFunctionAssigner<I1,I2>
A Join transformation that needs to be finished by specifying either a
JoinFunction or a
FlatJoinFunction before it can be used as an input to other operators. |
class |
JoinOperatorSetsBase<I1,I2>
Intermediate step of an Outer Join transformation.
|
class |
JoinType
Join types.
|
Modifier and Type | Class and Description |
---|---|
class |
Tuple
The base class of all tuples.
|
class |
Tuple0
A tuple with 0 fields.
|
class |
Tuple1<T0>
A tuple with 1 fields.
|
class |
Tuple10<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9>
A tuple with 10 fields.
|
class |
Tuple11<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10>
A tuple with 11 fields.
|
class |
Tuple12<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11>
A tuple with 12 fields.
|
class |
Tuple13<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12>
A tuple with 13 fields.
|
class |
Tuple14<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13>
A tuple with 14 fields.
|
class |
Tuple15<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14>
A tuple with 15 fields.
|
class |
Tuple16<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15>
A tuple with 16 fields.
|
class |
Tuple17<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16>
A tuple with 17 fields.
|
class |
Tuple18<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17>
A tuple with 18 fields.
|
class |
Tuple19<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18>
A tuple with 19 fields.
|
class |
Tuple2<T0,T1>
A tuple with 2 fields.
|
class |
Tuple20<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19>
A tuple with 20 fields.
|
class |
Tuple21<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20>
A tuple with 21 fields.
|
class |
Tuple22<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21>
A tuple with 22 fields.
|
class |
Tuple23<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22>
A tuple with 23 fields.
|
class |
Tuple24<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23>
A tuple with 24 fields.
|
class |
Tuple25<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24>
A tuple with 25 fields.
|
class |
Tuple3<T0,T1,T2>
A tuple with 3 fields.
|
class |
Tuple4<T0,T1,T2,T3>
A tuple with 4 fields.
|
class |
Tuple5<T0,T1,T2,T3,T4>
A tuple with 5 fields.
|
class |
Tuple6<T0,T1,T2,T3,T4,T5>
A tuple with 6 fields.
|
class |
Tuple7<T0,T1,T2,T3,T4,T5,T6>
A tuple with 7 fields.
|
class |
Tuple8<T0,T1,T2,T3,T4,T5,T6,T7>
A tuple with 8 fields.
|
class |
Tuple9<T0,T1,T2,T3,T4,T5,T6,T7,T8>
A tuple with 9 fields.
|
Modifier and Type | Class and Description |
---|---|
class |
Tuple0Builder
A builder class for
Tuple0 . |
class |
Tuple10Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9>
A builder class for
Tuple10 . |
class |
Tuple11Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10>
A builder class for
Tuple11 . |
class |
Tuple12Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11>
A builder class for
Tuple12 . |
class |
Tuple13Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12>
A builder class for
Tuple13 . |
class |
Tuple14Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13>
A builder class for
Tuple14 . |
class |
Tuple15Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14>
A builder class for
Tuple15 . |
class |
Tuple16Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15>
A builder class for
Tuple16 . |
class |
Tuple17Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16>
A builder class for
Tuple17 . |
class |
Tuple18Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17>
A builder class for
Tuple18 . |
class |
Tuple19Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18>
A builder class for
Tuple19 . |
class |
Tuple1Builder<T0>
A builder class for
Tuple1 . |
class |
Tuple20Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19>
A builder class for
Tuple20 . |
class |
Tuple21Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20>
A builder class for
Tuple21 . |
class |
Tuple22Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21>
A builder class for
Tuple22 . |
class |
Tuple23Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22>
A builder class for
Tuple23 . |
class |
Tuple24Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23>
A builder class for
Tuple24 . |
class |
Tuple25Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24>
A builder class for
Tuple25 . |
class |
Tuple2Builder<T0,T1>
A builder class for
Tuple2 . |
class |
Tuple3Builder<T0,T1,T2>
A builder class for
Tuple3 . |
class |
Tuple4Builder<T0,T1,T2,T3>
A builder class for
Tuple4 . |
class |
Tuple5Builder<T0,T1,T2,T3,T4>
A builder class for
Tuple5 . |
class |
Tuple6Builder<T0,T1,T2,T3,T4,T5>
A builder class for
Tuple6 . |
class |
Tuple7Builder<T0,T1,T2,T3,T4,T5,T6>
A builder class for
Tuple7 . |
class |
Tuple8Builder<T0,T1,T2,T3,T4,T5,T6,T7>
A builder class for
Tuple8 . |
class |
Tuple9Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8>
A builder class for
Tuple9 . |
Modifier and Type | Class and Description |
---|---|
class |
EitherTypeInfo<L,R>
A
TypeInformation for the Either type of the Java API. |
class |
EnumTypeInfo<T extends Enum<T>>
A
TypeInformation for java enumeration types. |
class |
GenericTypeInfo<T> |
interface |
InputTypeConfigurable
OutputFormat s can implement this interface to be
configured with the data type they will operate on. |
class |
ObjectArrayTypeInfo<T,C> |
class |
PojoTypeInfo<T>
TypeInformation for "Java Beans"-style types.
|
interface |
ResultTypeQueryable<T>
This interface can be implemented by functions and input formats to tell the framework about
their produced data type.
|
class |
TupleTypeInfo<T extends Tuple>
A
TypeInformation for the tuple types of the Java API. |
class |
TypeExtractor
A utility for reflection analysis on classes, to determine the return type of implementations of
transformation functions.
|
class |
ValueTypeInfo<T extends Value>
Type information for data types that extend the
Value interface. |
class |
WritableTypeInfo<T extends org.apache.hadoop.io.Writable>
Type information for data types that extend Hadoop's
Writable interface. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractParameterTool
This class provides common utility methods of
ParameterTool and MultipleParameterTool . |
class |
ParameterTool
This class provides simple utility methods for reading and parsing program arguments from
different sources.
|
Modifier and Type | Class and Description |
---|---|
class |
ScalaAggregateOperator<IN>
This operator represents the application of a "aggregate" operation on a data set, and the result
data set produced by the function.
|
Modifier and Type | Class and Description |
---|---|
class |
ConfigConstants
This class contains all constants for the configuration.
|
class |
Configuration
Lightweight configuration object which stores key/value pairs.
|
class |
UnmodifiableConfiguration
Unmodifiable version of the Configuration class.
|
Modifier and Type | Interface and Description |
---|---|
interface |
BlockLocation
A BlockLocation lists hosts, offset and length of block.
|
class |
FileInputSplit
A file input split provides information on a particular part of a file, possibly hosted on a
distributed file system and replicated among several hosts.
|
interface |
FileStatus
Interface that represents the client side information for a file independent of the file system.
|
class |
FileSystem
Abstract base class of all file systems used by Flink.
|
class |
FSDataInputStream
Interface for a data input stream to a file on a
FileSystem . |
class |
FSDataOutputStream
An output stream to a file that is created via a
FileSystem . |
class |
Path
Names a file or directory in a
FileSystem . |
Modifier and Type | Class and Description |
---|---|
class |
GenericInputSplit
A generic input split that has only a partition number.
|
interface |
InputSplit
This interface must be implemented by all kind of input splits that can be assigned to input
formats.
|
interface |
InputSplitSource<T extends InputSplit>
InputSplitSources create
InputSplit s that define portions of data to be produced by
InputFormat s. |
interface |
IOReadableWritable
This interface must be implemented by every class whose objects have to be serialized to their
binary representation and vice-versa.
|
class |
LocatableInputSplit
A locatable input split is an input split referring to input data which is located on one or more
hosts.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DataInputView
This interface defines a view over some memory that can be used to sequentially read the contents
of the memory.
|
interface |
DataOutputView
This interface defines a view over some memory that can be used to sequentially write contents to
the memory.
|
Modifier and Type | Class and Description |
---|---|
class |
HadoopMapFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
This wrapper maps a Hadoop Mapper (mapred API) to a Flink FlatMapFunction.
|
class |
HadoopReduceCombineFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
This wrapper maps a Hadoop Reducer and Combiner (mapred API) to a combinable Flink
GroupReduceFunction.
|
class |
HadoopReduceFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
This wrapper maps a Hadoop Reducer (mapred API) to a non-combinable Flink GroupReduceFunction.
|
Modifier and Type | Interface and Description |
---|---|
interface |
InputSplitProvider
An input split provider can be successively queried to provide a series of
InputSplit
objects a task is supposed to consume in the course of its execution. |
Modifier and Type | Interface and Description |
---|---|
interface |
CheckpointListener
This interface must be implemented by functions/operations that want to receive a commit
notification once a checkpoint has been completely acknowledged by all participants.
|
class |
VoidNamespaceTypeInfo
|
Modifier and Type | Class and Description |
---|---|
class |
CheckpointingMode
The checkpointing mode defines what consistency guarantees the system gives in the presence of
failures.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CheckpointedFunction
This is the core interface for stateful transformation functions, meaning functions that
maintain state across individual stream records.
|
Modifier and Type | Class and Description |
---|---|
class |
AllWindowedStream<T,W extends Window>
A
AllWindowedStream represents a data stream where the stream of elements is split into
windows based on a WindowAssigner . |
class |
CoGroupedStreams<T1,T2>
CoGroupedStreams represents two DataStreams that have been co-grouped. |
class |
CoGroupedStreams.Where<KEY>
CoGrouped streams that have the key for one side defined.
|
class |
CoGroupedStreams.Where.EqualTo
A co-group operation that has
KeySelectors defined for both inputs. |
static class |
CoGroupedStreams.WithWindow<T1,T2,KEY,W extends Window>
A co-group operation that has
KeySelectors defined for both inputs as
well as a WindowAssigner . |
class |
ConnectedStreams<IN1,IN2>
ConnectedStreams represent two connected streams of (possibly) different data types.
|
class |
DataStream<T>
A DataStream represents a stream of elements of the same type.
|
class |
DataStreamSink<T>
A Stream Sink.
|
class |
DataStreamSource<T>
The DataStreamSource represents the starting point of a DataStream.
|
static class |
IterativeStream.ConnectedIterativeStreams<I,F>
The
IterativeStream.ConnectedIterativeStreams represent a start of an iterative part of a streaming
program, where the original input of the iteration and the feedback of the iteration are
connected as in a ConnectedStreams . |
class |
JoinedStreams<T1,T2>
JoinedStreams represents two DataStreams that have been joined. |
class |
JoinedStreams.Where<KEY>
Joined streams that have the key for one side defined.
|
class |
JoinedStreams.Where.EqualTo
A join operation that has
KeySelectors defined for both inputs. |
static class |
JoinedStreams.WithWindow<T1,T2,KEY,W extends Window>
A join operation that has
KeySelectors defined for both inputs as well as
a WindowAssigner . |
class |
KeyedStream<T,KEY>
A
KeyedStream represents a DataStream on which operator state is partitioned by
key using a provided KeySelector . |
class |
SingleOutputStreamOperator<T>
SingleOutputStreamOperator represents a user defined transformation applied on a DataStream with one predefined output type. |
class |
WindowedStream<T,K,W extends Window>
A
WindowedStream represents a data stream where elements are grouped by key, and for each
key, the stream of elements is split into windows based on a WindowAssigner . |
Modifier and Type | Class and Description |
---|---|
class |
CheckpointConfig
Configuration that captures all checkpointing related settings.
|
class |
LocalStreamEnvironment
The LocalStreamEnvironment is a StreamExecutionEnvironment that runs the program locally,
multi-threaded, in the JVM where the environment is instantiated.
|
class |
RemoteStreamEnvironment
A
StreamExecutionEnvironment for executing on a cluster. |
class |
StreamExecutionEnvironment
The StreamExecutionEnvironment is the context in which a streaming program is executed.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CoFlatMapFunction<IN1,IN2,OUT>
A CoFlatMapFunction implements a flat-map transformation over two connected streams.
|
interface |
CoMapFunction<IN1,IN2,OUT>
A CoFlatMapFunction implements a map() transformation over two connected streams.
|
class |
RichCoFlatMapFunction<IN1,IN2,OUT>
A RichCoFlatMapFunction represents a FlatMap transformation with two different input types.
|
class |
RichCoMapFunction<IN1,IN2,OUT>
A RichCoMapFunction represents a Map transformation with two different input types.
|
Modifier and Type | Class and Description |
---|---|
class |
DiscardingSink<T>
A stream sink that ignores all elements.
|
class |
RichSinkFunction<IN>
A
RichFunction version of SinkFunction . |
interface |
SinkFunction<IN>
Interface for implementing user defined sink functionality.
|
static interface |
SinkFunction.Context<T>
Context that
SinkFunctions can use for getting additional data about an
input record. |
Modifier and Type | Interface and Description |
---|---|
interface |
ParallelSourceFunction<OUT>
A stream data source that is executed in parallel.
|
class |
RichParallelSourceFunction<OUT>
Base class for implementing a parallel data source.
|
class |
RichSourceFunction<OUT>
Base class for implementing a parallel data source that has access to context information (via
AbstractRichFunction.getRuntimeContext() ) and additional life-cycle methods (AbstractRichFunction.open(org.apache.flink.configuration.Configuration) and AbstractRichFunction.close() . |
interface |
SourceFunction<T>
Base interface for all stream data sources in Flink.
|
static interface |
SourceFunction.SourceContext<T>
Interface that source functions use to emit elements, and possibly watermarks.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AllWindowFunction<IN,OUT,W extends Window>
Base interface for functions that are evaluated over non-keyed windows.
|
class |
RichAllWindowFunction<IN,OUT,W extends Window>
A
RichFunction version of AllWindowFunction . |
class |
RichWindowFunction<IN,OUT,KEY,W extends Window>
Rich variant of the
WindowFunction . |
interface |
WindowFunction<IN,OUT,KEY,W extends Window>
Base interface for functions that are evaluated over keyed (grouped) windows.
|
Modifier and Type | Class and Description |
---|---|
class |
Time
The definition of a time interval for windowing.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DeserializationSchema<T>
Deprecated.
Use
DeserializationSchema instead. |
interface |
SerializationSchema<T>
Deprecated.
Use
SerializationSchema instead. |
class |
TypeInformationSerializationSchema<T>
Deprecated.
Use
TypeInformationSerializationSchema instead. |
Modifier and Type | Class and Description |
---|---|
class |
BooleanValue
Boxed serializable and comparable boolean type, representing the primitive type
boolean . |
class |
ByteValue
Boxed serializable and comparable byte type, representing the primitive type
byte (signed
8 bit integer). |
class |
CharValue
Boxed serializable and comparable character type, representing the primitive type
char . |
interface |
CopyableValue<T>
Interface to be implemented by basic types that support to be copied efficiently.
|
class |
DeserializationException
An exception specifying that the deserialization caused an error.
|
class |
DoubleValue
Boxed serializable and comparable double precision floating point type, representing the
primitive type
double . |
class |
Either<L,R>
This type represents a value of one two possible types, Left or Right (a disjoint union),
inspired by Scala's Either type.
|
class |
FloatValue
Boxed serializable and comparable single precision floating point type, representing the
primitive type
float . |
class |
IntValue
Boxed serializable and comparable integer type, representing the primitive type
int . |
class |
KeyFieldOutOfBoundsException
An exception specifying that a required key field was not set in a record, i.e.
|
class |
ListValue<V extends Value>
Generic list base type for PACT programs that implements the Value and List interfaces.
|
class |
LongValue
Boxed serializable and comparable long integer type, representing the primitive type
long . |
class |
MapValue<K extends Value,V extends Value>
Generic map base type for PACT programs that implements the Value and Map interfaces.
|
interface |
NormalizableKey<T>
The base interface for normalizable keys.
|
class |
Nothing
A type for (synthetic) operators that do not output data.
|
class |
NullFieldException
An exception specifying that a required field was not set in a record, i.e.
|
class |
NullKeyFieldException
An exception specifying that a required key field was not set in a record, i.e.
|
class |
NullValue
Null base type for programs that implements the Key interface.
|
class |
Record
The Record represents a multi-valued data record.
|
interface |
ResettableValue<T extends Value> |
class |
ShortValue
Boxed serializable and comparable short integer type, representing the primitive type
short . |
class |
StringValue
Mutable string data type that implements the Key interface.
|
interface |
Value
Basic value interface for types that act as serializable values.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Collector<T>
Collects a record and forwards it.
|
class |
DynamicCodeLoadingException
An exception that is thrown if the dynamic instantiation of code fails.
|
class |
FlinkException
Base class of all Flink-specific checked exceptions.
|
class |
FlinkRuntimeException
Base class of all Flink-specific unchecked exceptions.
|
class |
LongValueSequenceIterator
The
LongValueSequenceIterator is an iterator that returns a sequence of numbers (as
LongValue )s. |
class |
NumberSequenceIterator
The
NumberSequenceIterator is an iterator that returns a sequence of numbers (as Long )s. |
class |
SplittableIterator<T>
Abstract base class for iterators that can split themselves into multiple disjoint iterators.
|
class |
TemporaryClassLoaderContext
Sets a context class loader in a "try-with-resources" pattern.
|
class |
TraversableOnceException
An exception, indicating that an
Iterable can only be traversed once, but has
been attempted to traverse an additional time. |
class |
XORShiftRandom
Implement a random number generator based on the XORShift algorithm discovered by George
Marsaglia.
|
Modifier and Type | Interface and Description |
---|---|
interface |
FunctionWithException<T,R,E extends Throwable>
A functional interface for a
Function that may throw exceptions. |
interface |
LongFunctionWithException<R,E extends Throwable>
Similar to
LongFunction but can throw Exception . |
interface |
RunnableWithException
Similar to a
Runnable , this interface is used to capture a block of code to be executed. |
interface |
SupplierWithException<R,E extends Throwable>
A functional interface for a
Supplier that may throw exceptions. |
interface |
ThrowingConsumer<T,E extends Throwable>
This interface is basically Java's
Consumer interface enhanced with
the ability to throw an exception. |
Modifier and Type | Class and Description |
---|---|
class |
TransactionSource
A stream of transactions.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.