Uses of Class
org.apache.flink.annotation.Public
-
-
Uses of Public in org.apache.flink
Classes in org.apache.flink with annotations of type Public Modifier and Type Class Description class
FlinkVersion
Enumeration for Flink versions. -
Uses of Public in org.apache.flink.annotation
Classes in org.apache.flink.annotation with annotations of type Public Modifier and Type Class 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. -
Uses of Public in org.apache.flink.api.common
Classes in org.apache.flink.api.common with annotations of type Public Modifier and Type Class Description class
ExecutionConfig
A config to define the behavior of the program execution.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 theInvalidProgramException
, indicating that a part of the program that needs to be serializable (for shipping) is not serializable. -
Uses of Public in org.apache.flink.api.common.accumulators
Classes in org.apache.flink.api.common.accumulators with annotations of type Public Modifier and Type Interface 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. -
Uses of Public in org.apache.flink.api.common.cache
Classes in org.apache.flink.api.common.cache with annotations of type Public Modifier and Type Class Description class
DistributedCache
DistributedCache provides static methods to write the registered cache files into job configuration or decode them from job configuration. -
Uses of Public in org.apache.flink.api.common.eventtime
Classes in org.apache.flink.api.common.eventtime with annotations of type Public Modifier and Type Class 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 aWatermarkGenerator
that generates no Watermarks.class
RecordTimestampAssigner<E>
ATimestampAssigner
that forwards the already-assigned timestamp.interface
TimestampAssigner<T>
ATimestampAssigner
assigns event time timestamps to elements.class
Watermark
Watermarks are the progress indicators in the data streams.interface
WatermarkGenerator<T>
TheWatermarkGenerator
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 generateWatermark
s in the stream sources.class
WatermarksWithIdleness<T>
A WatermarkGenerator that adds idleness detection to another WatermarkGenerator. -
Uses of Public in org.apache.flink.api.common.functions
Classes in org.apache.flink.api.common.functions with annotations of type Public Modifier and Type Class 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
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 theInvalidProgramException
, indicating that the types used in an operation are invalid or inconsistent.interface
IterationRuntimeContext
A specialization of theRuntimeContext
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
OpenContext
TheOpenContext
interface provides necessary information required by theRichFunction
when it is opened.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 theCoGroupFunction
.class
RichCrossFunction<IN1,IN2,OUT>
Rich variant of theCrossFunction
.class
RichFilterFunction<T>
Rich variant of theFilterFunction
.class
RichFlatJoinFunction<IN1,IN2,OUT>
Rich variant of theFlatJoinFunction
.class
RichFlatMapFunction<IN,OUT>
Rich variant of theFlatMapFunction
.interface
RichFunction
An base interface for all rich user-defined functions.class
RichGroupCombineFunction<IN,OUT>
Rich variant of theGroupCombineFunction
.class
RichGroupReduceFunction<IN,OUT>
Rich variant of theGroupReduceFunction
.class
RichJoinFunction<IN1,IN2,OUT>
Rich variant of theJoinFunction
.class
RichMapFunction<IN,OUT>
Rich variant of theMapFunction
.class
RichMapPartitionFunction<I,O>
Rich variant of theMapPartitionFunction
.class
RichReduceFunction<T>
Rich variant of theReduceFunction
.interface
RuntimeContext
A RuntimeContext contains information about the context in which functions are executed. -
Uses of Public in org.apache.flink.api.common.io
Classes in org.apache.flink.api.common.io with annotations of type Public Modifier and Type Class 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 forRichInputFormat
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 byOutputFormat
s to have the master finalize them globally.static interface
FinalizeOnMaster.FinalizationContext
A context that provides parallelism and finished attempts infos.class
GenericInputFormat<OT>
Generic base class for all Rich inputs that are not based on files.interface
InitializeOnMaster
This interface may be implemented byOutputFormat
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 anInputStream
and exposes it asFSDataInputStream
.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.static interface
OutputFormat.InitializationContext
The context exposes some runtime info for initializing output format.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. -
Uses of Public in org.apache.flink.api.common.io.statistics
Classes in org.apache.flink.api.common.io.statistics with annotations of type Public Modifier and Type Interface Description interface
BaseStatistics
Interface describing the basic statistics that can be obtained from the input. -
Uses of Public in org.apache.flink.api.common.operators
Classes in org.apache.flink.api.common.operators with annotations of type Public Modifier and Type Class Description class
Order
Enumeration representing order. -
Uses of Public in org.apache.flink.api.common.operators.base
Classes in org.apache.flink.api.common.operators.base with annotations of type Public Modifier and Type Class Description static class
CrossOperatorBase.CrossHint
The cross hint tells the system which sizes to expect from the data setsstatic class
JoinOperatorBase.JoinHint
An enumeration of hints, optionally usable to tell the system how exactly execute the join. -
Uses of Public in org.apache.flink.api.common.serialization
Classes in org.apache.flink.api.common.serialization with annotations of type Public Modifier and Type Interface 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. -
Uses of Public in org.apache.flink.api.common.state
Classes in org.apache.flink.api.common.state with annotations of type Public Modifier and Type Interface Description interface
CheckpointListener
This interface is typically only needed for transactional interaction with the "outside world", like committing external side effects on checkpoints. -
Uses of Public in org.apache.flink.api.common.typeinfo
Classes in org.apache.flink.api.common.typeinfo with annotations of type Public Modifier and Type Interface 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 theNothing
type.class
NumericTypeInfo<T>
Type information for numeric primitive types: int, long, double, byte, short, float, char.class
PrimitiveArrayTypeInfo<T>
ATypeInformation
for arrays of primitive types (int, long, double, ...).class
TypeHint<T>
A utility class for describing generic types.interface
TypeInfo
Annotation for specifying a correspondingTypeInfoFactory
that can produceTypeInformation
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. -
Uses of Public in org.apache.flink.api.common.typeutils
Classes in org.apache.flink.api.common.typeutils with annotations of type Public Modifier and Type Class Description class
CompositeType<T>
Base type information class for Tuple and Pojo types -
Uses of Public in org.apache.flink.api.connector.sink2
Classes in org.apache.flink.api.connector.sink2 with annotations of type Public Modifier and Type Interface Description interface
Committer<CommT>
TheCommitter
is responsible for committing the data staged by theCommittingSinkWriter
in the second step of a two-phase commit protocol.static interface
Committer.CommitRequest<CommT>
A request to commit a specific committable.interface
CommitterInitContext
The interface exposes some runtime info for creating aCommitter
.interface
CommittingSinkWriter<InputT,CommittableT>
ASinkWriter
that performs the first part of a two-phase commit protocol.interface
Sink<InputT>
Base interface for developing a sink.interface
SinkWriter<InputT>
TheSinkWriter
is responsible for writing data.static interface
SinkWriter.Context
Context thatSinkWriter.write(InputT, org.apache.flink.api.connector.sink2.SinkWriter.Context)
can use for getting additional data about an input record.interface
StatefulSinkWriter<InputT,WriterStateT>
ASinkWriter
whose state needs to be checkpointed.interface
SupportsCommitter<CommittableT>
A mixin interface for aSink
which supports exactly-once semantics using a two-phase commit protocol.interface
SupportsWriterState<InputT,WriterStateT>
A mixin interface for aSink
which supports a statefulStatefulSinkWriter
.interface
WriterInitContext
The interface exposes some runtime info for creating aSinkWriter
. -
Uses of Public in org.apache.flink.api.connector.source
Classes in org.apache.flink.api.connector.source with annotations of type Public Modifier and Type Class Description class
Boundedness
The boundedness of a stream.class
ReaderInfo
A container class hosting the information of aSourceReader
.interface
ReaderOutput<T>
The interface provided by the Flink runtime to theSourceReader
to emit records, and optionally watermarks, to downstream operators for message processing.interface
Source<T,SplitT extends SourceSplit,EnumChkT>
The interface for Source.interface
SourceEvent
An base class for the events passed between the SourceReaders and Enumerators.interface
SourceOutput<T>
TheSourceOutput
is the gateway for aSourceReader
) to emit the produced records and watermarks.interface
SourceReader<T,SplitT extends SourceSplit>
The interface for a source reader which is responsible for reading the records from the source splits assigned bySplitEnumerator
.interface
SourceReaderContext
The interface that exposes some context from runtime to theSourceReader
.interface
SourceReaderFactory<T,SplitT extends SourceSplit>
A factory for creating source reader instances.interface
SourceSplit
An interface for all the Split types to extend.interface
SplitEnumerator<SplitT extends SourceSplit,CheckpointT>
The interface for a split enumerator responsible for discovering the source splits, and assigning them to theSourceReader
.interface
SplitEnumeratorContext<SplitT extends SourceSplit>
A context class for theSplitEnumerator
.class
SplitsAssignment<SplitT extends SourceSplit>
A class containing the splits assignment to the source readers. -
Uses of Public in org.apache.flink.api.connector.source.lib
Classes in org.apache.flink.api.connector.source.lib with annotations of type Public Modifier and Type Class Description class
NumberSequenceSource
A data source that produces a sequence of numbers (longs). -
Uses of Public in org.apache.flink.api.connector.source.lib.util
Classes in org.apache.flink.api.connector.source.lib.util with annotations of type Public Modifier and Type Class Description class
IteratorSourceEnumerator<SplitT extends IteratorSourceSplit<?,?>>
ASplitEnumerator
for iterator sources.class
IteratorSourceReader<E,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>>
ASourceReader
that returns the values of an iterator, supplied via anIteratorSourceSplit
.class
IteratorSourceReaderBase<E,O,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>>
ASourceReader
that returns the values of an iterator, supplied via anIteratorSourceSplit
.interface
IteratorSourceSplit<E,IterT extends Iterator<E>>
ASourceSplit
that represents a sequence of elements captured in an iterator. -
Uses of Public in org.apache.flink.api.java.functions
Classes in org.apache.flink.api.java.functions with annotations of type Public Modifier and Type Interface Description interface
KeySelector<IN,KEY>
TheKeySelector
allows to use deterministic objects for operations such as reduce, reduceGroup, join, coGroup, etc. -
Uses of Public in org.apache.flink.api.java.hadoop.mapred
Classes in org.apache.flink.api.java.hadoop.mapred with annotations of type Public Modifier and Type Class 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. -
Uses of Public in org.apache.flink.api.java.hadoop.mapreduce
Classes in org.apache.flink.api.java.hadoop.mapreduce with annotations of type Public Modifier and Type Class 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. -
Uses of Public in org.apache.flink.api.java.tuple
Classes in org.apache.flink.api.java.tuple with annotations of type Public Modifier and Type Class 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. -
Uses of Public in org.apache.flink.api.java.tuple.builder
Classes in org.apache.flink.api.java.tuple.builder with annotations of type Public Modifier and Type Class Description class
Tuple0Builder
A builder class forTuple0
.class
Tuple10Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9>
A builder class forTuple10
.class
Tuple11Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10>
A builder class forTuple11
.class
Tuple12Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11>
A builder class forTuple12
.class
Tuple13Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12>
A builder class forTuple13
.class
Tuple14Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13>
A builder class forTuple14
.class
Tuple15Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14>
A builder class forTuple15
.class
Tuple16Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15>
A builder class forTuple16
.class
Tuple17Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16>
A builder class forTuple17
.class
Tuple18Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17>
A builder class forTuple18
.class
Tuple19Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18>
A builder class forTuple19
.class
Tuple1Builder<T0>
A builder class forTuple1
.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 forTuple20
.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 forTuple21
.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 forTuple22
.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 forTuple23
.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 forTuple24
.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 forTuple25
.class
Tuple2Builder<T0,T1>
A builder class forTuple2
.class
Tuple3Builder<T0,T1,T2>
A builder class forTuple3
.class
Tuple4Builder<T0,T1,T2,T3>
A builder class forTuple4
.class
Tuple5Builder<T0,T1,T2,T3,T4>
A builder class forTuple5
.class
Tuple6Builder<T0,T1,T2,T3,T4,T5>
A builder class forTuple6
.class
Tuple7Builder<T0,T1,T2,T3,T4,T5,T6>
A builder class forTuple7
.class
Tuple8Builder<T0,T1,T2,T3,T4,T5,T6,T7>
A builder class forTuple8
.class
Tuple9Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8>
A builder class forTuple9
. -
Uses of Public in org.apache.flink.api.java.typeutils
Classes in org.apache.flink.api.java.typeutils with annotations of type Public Modifier and Type Class Description class
EitherTypeInfo<L,R>
ATypeInformation
for theEither
type of the Java API.class
EnumTypeInfo<T extends Enum<T>>
ATypeInformation
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>
ATypeInformation
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 theValue
interface.class
WritableTypeInfo<T extends org.apache.hadoop.io.Writable>
Type information for data types that extend Hadoop'sWritable
interface. -
Uses of Public in org.apache.flink.configuration
Classes in org.apache.flink.configuration with annotations of type Public Modifier and Type Class 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. -
Uses of Public in org.apache.flink.core.execution
Classes in org.apache.flink.core.execution with annotations of type Public Modifier and Type Class Description class
CheckpointingMode
The checkpointing mode defines what consistency guarantees the system gives in the presence of failures. -
Uses of Public in org.apache.flink.core.fs
Classes in org.apache.flink.core.fs with annotations of type Public Modifier and Type Interface 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 aFileSystem
.class
FSDataOutputStream
An output stream to a file that is created via aFileSystem
.interface
LocatedFileStatus
ALocatedFileStatus
is aFileStatus
that contains additionally the location information of the file directly.class
Path
Names a file or directory in aFileSystem
. -
Uses of Public in org.apache.flink.core.io
Classes in org.apache.flink.core.io with annotations of type Public Modifier and Type Class 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 createInputSplit
s that define portions of data to be produced byInputFormat
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. -
Uses of Public in org.apache.flink.core.memory
Classes in org.apache.flink.core.memory with annotations of type Public Modifier and Type Interface 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. -
Uses of Public in org.apache.flink.hadoopcompatibility.mapred
Classes in org.apache.flink.hadoopcompatibility.mapred with annotations of type Public Modifier and Type Class Description class
HadoopMapFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
This wrapper maps a Hadoop Mapper (mapred API) to a Flink FlatMapFunction.class
HadoopReducerWrappedFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
This wrapper maps a Hadoop Reducer (mapred API) to a Flink window function. -
Uses of Public in org.apache.flink.metrics
Classes in org.apache.flink.metrics with annotations of type Public Modifier and Type Interface Description interface
CharacterFilter
Interface for a character filter function.interface
Counter
A Counter is aMetric
that measures a count.interface
Gauge<T>
A Gauge is aMetric
that calculates a specific value at a point in time.interface
Histogram
Histogram interface to be used with Flink's metrics system.class
HistogramStatistics
Histogram statistics represent the current snapshot of elements recorded in the histogram.interface
LogicalScopeProvider
Extension for metric groups that support logical scopes.interface
Meter
Metric for measuring throughput.interface
Metric
Common super interface for all metrics.class
MetricConfig
A properties class with added utility method to extract primitives.interface
MetricGroup
A MetricGroup is a named container forMetrics
and further metric subgroups.class
MetricType
Enum describing the different metric types.interface
View
An interface for metrics which should be updated in regular intervals by a background thread. -
Uses of Public in org.apache.flink.metrics.reporter
Classes in org.apache.flink.metrics.reporter with annotations of type Public Modifier and Type Class Description class
AbstractReporter
Base interface for custom metric reporters.interface
MetricReporter
Metric reporters are used to exportMetrics
to an external backend.interface
MetricReporterFactory
MetricReporter
factory.interface
Scheduled
Interface for reporters that actively send out data periodically. -
Uses of Public in org.apache.flink.runtime.jobgraph.tasks
Classes in org.apache.flink.runtime.jobgraph.tasks with annotations of type Public Modifier and Type Interface Description interface
InputSplitProvider
An input split provider can be successively queried to provide a series ofInputSplit
objects a task is supposed to consume in the course of its execution. -
Uses of Public in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state with annotations of type Public Modifier and Type Class Description class
VoidNamespaceTypeInfo
-
Uses of Public in org.apache.flink.streaming.api
Classes in org.apache.flink.streaming.api with annotations of type Public Modifier and Type Class Description class
CheckpointingMode
Deprecated.This class has been moved toCheckpointingMode
. -
Uses of Public in org.apache.flink.streaming.api.checkpoint
Classes in org.apache.flink.streaming.api.checkpoint with annotations of type Public Modifier and Type Interface Description interface
CheckpointedFunction
This is the core interface for stateful transformation functions, meaning functions that maintain state across individual stream records. -
Uses of Public in org.apache.flink.streaming.api.datastream
Classes in org.apache.flink.streaming.api.datastream with annotations of type Public Modifier and Type Class Description class
AllWindowedStream<T,W extends Window>
AAllWindowedStream
represents a data stream where the stream of elements is split into windows based on aWindowAssigner
.class
CoGroupedStreams<T1,T2>
CoGroupedStreams
represents twoDataStreams
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 hasKeySelectors
defined for both inputs.static class
CoGroupedStreams.WithWindow<T1,T2,KEY,W extends Window>
A co-group operation that hasKeySelectors
defined for both inputs as well as aWindowAssigner
.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.class
JoinedStreams<T1,T2>
JoinedStreams
represents twoDataStreams
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 hasKeySelectors
defined for both inputs.static class
JoinedStreams.WithWindow<T1,T2,KEY,W extends Window>
A join operation that hasKeySelectors
defined for both inputs as well as aWindowAssigner
.class
KeyedStream<T,KEY>
AKeyedStream
represents aDataStream
on which operator state is partitioned by key using a providedKeySelector
.class
SideOutputDataStream<T>
ASideOutputDataStream
represents aDataStream
that contains elements that are emitted from upstream into a side output with some tag.class
SingleOutputStreamOperator<T>
SingleOutputStreamOperator
represents a user defined transformation applied on aDataStream
with one predefined output type.class
WindowedStream<T,K,W extends Window>
AWindowedStream
represents a data stream where elements are grouped by key, and for each key, the stream of elements is split into windows based on aWindowAssigner
. -
Uses of Public in org.apache.flink.streaming.api.environment
Classes in org.apache.flink.streaming.api.environment with annotations of type Public Modifier and Type Class 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
AStreamExecutionEnvironment
for executing on a cluster.class
StreamExecutionEnvironment
The StreamExecutionEnvironment is the context in which a streaming program is executed. -
Uses of Public in org.apache.flink.streaming.api.functions.co
Classes in org.apache.flink.streaming.api.functions.co with annotations of type Public Modifier and Type Interface 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. -
Uses of Public in org.apache.flink.streaming.api.functions.sink.legacy
Classes in org.apache.flink.streaming.api.functions.sink.legacy with annotations of type Public Modifier and Type Interface Description static interface
SinkFunction.Context
Deprecated.Context thatSinkFunctions
can use for getting additional data about an input record. -
Uses of Public in org.apache.flink.streaming.api.functions.source.legacy
Classes in org.apache.flink.streaming.api.functions.source.legacy with annotations of type Public Modifier and Type Interface Description static interface
SourceFunction.SourceContext<T>
Deprecated.Interface that source functions use to emit elements, and possibly watermarks. -
Uses of Public in org.apache.flink.streaming.api.functions.windowing
Classes in org.apache.flink.streaming.api.functions.windowing with annotations of type Public Modifier and Type Interface 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>
ARichFunction
version ofAllWindowFunction
.class
RichWindowFunction<IN,OUT,KEY,W extends Window>
Rich variant of theWindowFunction
.interface
WindowFunction<IN,OUT,KEY,W extends Window>
Base interface for functions that are evaluated over keyed (grouped) windows. -
Uses of Public in org.apache.flink.types
Classes in org.apache.flink.types with annotations of type Public Modifier and Type Class Description class
BooleanValue
Boxed serializable and comparable boolean type, representing the primitive typeboolean
.class
ByteValue
Boxed serializable and comparable byte type, representing the primitive typebyte
(signed 8 bit integer).class
CharValue
Boxed serializable and comparable character type, representing the primitive typechar
.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 typedouble
.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 typefloat
.class
IntValue
Boxed serializable and comparable integer type, representing the primitive typeint
.class
KeyFieldOutOfBoundsException
An exception specifying that a required key field was not set in a record, i.e. wasnull
.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 typelong
.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. wasnull
.class
NullKeyFieldException
An exception specifying that a required key field was not set in a record, i.e. wasnull
.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 typeshort
.class
StringValue
Mutable string data type that implements the Key interface.interface
Value
Basic value interface for types that act as serializable values. -
Uses of Public in org.apache.flink.util
Classes in org.apache.flink.util with annotations of type Public Modifier and Type Class Description class
AbstractParameterTool
This class provides common utility methods ofParameterTool
andMultipleParameterTool
.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
TheLongValueSequenceIterator
is an iterator that returns a sequence of numbers (asLongValue
)s.class
NumberSequenceIterator
TheNumberSequenceIterator
is an iterator that returns a sequence of numbers (asLong
)s.class
ParameterTool
This class provides simple utility methods for reading and parsing program arguments from different sources.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 anIterable
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. -
Uses of Public in org.apache.flink.util.function
Classes in org.apache.flink.util.function with annotations of type Public Modifier and Type Interface Description interface
FunctionWithException<T,R,E extends Throwable>
A functional interface for aFunction
that may throw exceptions.interface
LongFunctionWithException<R,E extends Throwable>
Similar toLongFunction
but can throwException
.interface
RunnableWithException
Similar to aRunnable
, this interface is used to capture a block of code to be executed.interface
SerializableFunction<T,R>
AFunction
that is alsoSerializable
.interface
SupplierWithException<R,E extends Throwable>
A functional interface for aSupplier
that may throw exceptions.interface
ThrowingConsumer<T,E extends Throwable>
This interface is basically Java'sConsumer
interface enhanced with the ability to throw an exception.
-