Modifier and Type | Class and Description |
---|---|
static class |
FileSinkProgram.Generator
Data-generating source function.
|
Modifier and Type | Interface and Description |
---|---|
interface |
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. |
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 |
GroupCombineFunction<IN,OUT>
Generic interface used for combine functions ("combiners").
|
interface |
GroupReduceFunction<T,O>
The interface for group reduce functions.
|
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.
|
interface |
RichFunction
An base interface for all rich user-defined functions.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractRichFunction
An abstract stub implementation for rich user-defined functions.
|
class |
RichAggregateFunction<IN,ACC,OUT>
Rich variant of the
AggregateFunction . |
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 |
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 . |
Modifier and Type | Class and Description |
---|---|
class |
NoOpFunction
An
AbstractRichFunction that does nothing. |
Modifier and Type | Method and Description |
---|---|
static void |
FunctionUtils.closeFunction(Function function) |
static RuntimeContext |
FunctionUtils.getFunctionRuntimeContext(Function function,
RuntimeContext defaultContext) |
static void |
FunctionUtils.openFunction(Function function,
Configuration parameters) |
static void |
FunctionUtils.setFunctionRuntimeContext(Function function,
RuntimeContext context) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractUdfOperator<OUT,FT extends Function>
Abstract superclass for all contracts that represent actual operators.
|
class |
DualInputOperator<IN1,IN2,OUT,FT extends Function>
Abstract operator superclass for all operators that have two inputs, like "Join", "CoGroup", or
"Cross".
|
class |
SingleInputOperator<IN,OUT,FT extends Function>
Abstract superclass for for all operators that have one input like "map" or "reduce".
|
Modifier and Type | Class and Description |
---|---|
static class |
BulkIterationBase.TerminationCriterionMapper<X>
Special Mapper that is added before a termination criterion and is only a container for an
special aggregator
|
Modifier and Type | Interface and Description |
---|---|
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 |
FirstReducer<T>
Reducer that only emits the first N elements in a group.
|
class |
FlatMapIterator<IN,OUT>
A convenience variant of the
RichFlatMapFunction
that returns elements through an iterator, rather then through a collector. |
class |
FormattingMapper<T>
Mapper that converts values to strings using a
TextOutputFormat.TextFormatter . |
class |
GroupReduceIterator<IN,OUT>
Base class that simplifies reducing all values provided as
Iterable . |
class |
IdPartitioner
Partitioner that partitions by id.
|
class |
NullByteKeySelector<T>
Used as a dummy
KeySelector to allow using keyed operators for non-keyed use cases. |
class |
SampleInCoordinator<T>
SampleInCoordinator wraps the sample logic of the coordinator side (the second phase of
distributed sample algorithm).
|
class |
SampleInPartition<T>
SampleInPartition wraps the sample logic on the partition side (the first phase of distributed
sample algorithm).
|
class |
SampleWithFraction<T>
A map partition function wrapper for sampling algorithms with fraction, the sample algorithm
takes the partition iterator as input.
|
class |
SelectByMaxFunction<T extends Tuple>
Function that enables selection by maximal value of a field.
|
class |
SelectByMinFunction<T extends Tuple>
Function that enables selection by minimal value of a field.
|
Modifier and Type | Class and Description |
---|---|
static class |
SplitDataProperties.SourcePartitionerMarker<T>
A custom partitioner to mark compatible split partitionings.
|
Modifier and Type | Class and Description |
---|---|
static class |
CrossOperator.ProjectCrossFunction<T1,T2,R extends Tuple> |
static class |
JoinOperator.DefaultJoin.WrappingFlatJoinFunction<IN1,IN2,OUT>
Wrapper around
JoinFunction . |
Modifier and Type | Method and Description |
---|---|
protected abstract Function |
TwoInputUdfOperator.getFunction() |
protected abstract Function |
SingleInputUdfOperator.getFunction() |
protected Function |
CoGroupRawOperator.getFunction() |
Modifier and Type | Class and Description |
---|---|
class |
WrappingFunction<T extends Function>
Wrapper around
Function . |
Modifier and Type | Class and Description |
---|---|
class |
CombineToGroupCombineWrapper<IN,OUT,F extends CombineFunction<IN,IN> & GroupReduceFunction<IN,OUT>>
A wrapper the wraps a function that implements both
CombineFunction and GroupReduceFunction interfaces and makes it look like a function that implements GroupCombineFunction and GroupReduceFunction to the runtime. |
class |
KeyExtractingMapper<T,K>
Mapper that extracts keys.
|
class |
KeyRemovingMapper<T,K>
Mapper that removes keys.
|
static class |
PlanFilterOperator.FlatMapFilter<T> |
class |
RichCombineToGroupCombineWrapper<IN,OUT,F extends RichGroupReduceFunction<IN,OUT> & CombineFunction<IN,IN>>
A wrapper the wraps a function that implements both
CombineFunction and GroupReduceFunction interfaces and makes it look like a function that implements GroupCombineFunction and GroupReduceFunction to the runtime. |
class |
TupleLeftUnwrappingJoiner<I1,I2,OUT,K>
Joiner that unwraps values from the left set before applying the join operation.
|
class |
TupleRightUnwrappingJoiner<I1,I2,OUT,K>
Joiner that unwraps values from the right set before applying the join operation.
|
class |
TupleUnwrappingJoiner<I1,I2,OUT,K>
Joiner that unwraps both values before applying the join operation.
|
class |
TwoKeyExtractingMapper<T,K1,K2>
Mapper that extracts two keys of a value.
|
class |
WrappingFunction<T extends Function>
Wrapper around
Function . |
Modifier and Type | Field and Description |
---|---|
protected T |
WrappingFunction.wrappedFunction |
Modifier and Type | Method and Description |
---|---|
static TypeExtractionUtils.LambdaExecutable |
TypeExtractionUtils.checkAndExtractLambda(Function function)
Checks if the given function has been implemented using a Java 8 lambda.
|
static <IN1,IN2,OUT> |
TypeExtractor.getBinaryOperatorReturnType(Function function,
Class<?> baseClass,
int input1TypeArgumentIndex,
int input2TypeArgumentIndex,
int outputTypeArgumentIndex,
int[] lambdaOutputTypeArgumentIndices,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing)
Returns the binary operator's return type.
|
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getUnaryOperatorReturnType(Function function,
Class<?> baseClass,
int inputTypeArgumentIndex,
int outputTypeArgumentIndex,
int[] lambdaOutputTypeArgumentIndices,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing)
Returns the unary operator's return type.
|
Modifier and Type | Class and Description |
---|---|
class |
BlockingIncrementingMapFunction
A map function that increments values by one.
|
Modifier and Type | Interface and Description |
---|---|
interface |
PatternFlatSelectFunction<IN,OUT>
Base interface for a pattern select function which can produce multiple resulting elements.
|
interface |
PatternFlatTimeoutFunction<IN,OUT>
Base interface for a pattern timeout function which can produce multiple resulting elements.
|
interface |
PatternSelectFunction<IN,OUT>
Base interface for a pattern select function.
|
interface |
PatternTimeoutFunction<IN,OUT>
Base interface for a pattern timeout function.
|
Modifier and Type | Class and Description |
---|---|
static class |
PatternStream.CoMapTimeout<R,L>
Used for joining results from timeout side-output for API backward compatibility.
|
class |
RichPatternFlatSelectFunction<IN,OUT>
Rich variant of the
PatternFlatSelectFunction . |
class |
RichPatternSelectFunction<IN,OUT>
Rich variant of the
PatternSelectFunction . |
Modifier and Type | Class and Description |
---|---|
class |
PatternProcessFunction<IN,OUT>
It is called with a map of detected events which are identified by their names.
|
Modifier and Type | Class and Description |
---|---|
class |
PatternFlatSelectAdapter<IN,OUT>
Adapter that expresses
PatternFlatSelectFunction with PatternProcessFunction . |
class |
PatternSelectAdapter<IN,OUT>
Adapter that expresses
PatternSelectFunction with PatternProcessFunction . |
class |
PatternTimeoutFlatSelectAdapter<IN,OUT,T>
Adapter that expresses combination of
PatternFlatSelectFunction and PatternTimeoutFlatSelectAdapter with PatternProcessFunction . |
class |
PatternTimeoutSelectAdapter<IN,OUT,T>
Adapter that expresses combination of
PatternSelectFunction and PatternTimeoutFlatSelectAdapter with PatternProcessFunction . |
Modifier and Type | Class and Description |
---|---|
class |
AndCondition<T>
Deprecated.
Please use
RichAndCondition instead. This class exists just for backwards
compatibility and will be removed in FLINK-10113. |
class |
IterativeCondition<T>
A user-defined condition that decides if an element should be accepted in the pattern or not.
|
class |
NotCondition<T>
Deprecated.
Please use
RichNotCondition instead. This class exists just for backwards
compatibility and will be removed in FLINK-10113. |
class |
OrCondition<T>
Deprecated.
Please use
RichOrCondition instead. This class exists just for backwards
compatibility and will be removed in FLINK-10113. |
class |
RichAndCondition<T>
|
class |
RichCompositeIterativeCondition<T>
A base class of composite
IterativeCondition conditions such as RichAndCondition ,
RichOrCondition and RichNotCondition , etc. |
class |
RichIterativeCondition<T>
Rich variant of the
IterativeCondition . |
class |
RichNotCondition<T>
A
condition which negates the condition it wraps and returns
true if the original condition returns false . |
class |
RichOrCondition<T>
A
condition which combines two conditions with a logical OR and returns true if at least one is true . |
class |
SimpleCondition<T>
A user-defined condition that decides if an element should be accepted in the pattern or not.
|
class |
SubtypeCondition<T>
A
condition which filters elements of the given type. |
Modifier and Type | Interface and Description |
---|---|
interface |
ElasticsearchEmitter<T>
Creates none or multiple
ActionRequests from the incoming elements. |
Modifier and Type | Class and Description |
---|---|
class |
HBaseSinkFunction<T>
The sink function for HBase.
|
Modifier and Type | Class and Description |
---|---|
class |
GenericJdbcSinkFunction<T>
A generic SinkFunction for JDBC.
|
Modifier and Type | Class and Description |
---|---|
class |
JdbcXaSinkFunction<T>
JDBC sink function that uses XA transactions to provide exactly once guarantees.
|
Modifier and Type | Class and Description |
---|---|
static class |
KMeans.CentroidAccumulator
Sums and counts point coordinates.
|
static class |
KMeans.CentroidAverager
Computes new centroid from coordinate sum and count of points.
|
static class |
KMeans.CountAppender
Appends a count variable to the tuple.
|
static class |
KMeans.SelectNearestCenter
Determines the closest cluster center for a data point.
|
Modifier and Type | Class and Description |
---|---|
static class |
ConnectedComponents.ComponentIdFilter
Emit the candidate (Vertex-ID, Component-ID) pair if and only if the candidate component ID
is less than the vertex's current component ID.
|
static class |
ConnectedComponents.DuplicateValue<T>
Function that turns a value into a 2-tuple where both fields are that value.
|
static class |
ConnectedComponents.NeighborWithComponentIDJoin
UDF that joins a (Vertex-ID, Component-ID) pair that represents the current component that a
vertex is associated with, with a (Source-Vertex-ID, Target-VertexID) edge.
|
static class |
ConnectedComponents.UndirectEdge
Undirected edges by emitting for each input edge the input edges itself and an inverted
version.
|
static class |
EnumTriangles.TupleEdgeConverter
Converts a Tuple2 into an Edge.
|
static class |
PageRank.BuildOutgoingEdgeList
A reduce function that takes a sequence of edges and builds the adjacency list for the vertex
where the edges originate.
|
static class |
PageRank.Dampener
The function that applies the page rank dampening formula.
|
static class |
PageRank.EpsilonFilter
Filter that filters vertices where the rank difference is below a threshold.
|
static class |
PageRank.JoinVertexWithEdgesMatch
Join function that distributes a fraction of a vertex's rank to all neighbors.
|
static class |
PageRank.RankAssigner
A map function that assigns an initial rank to all pages.
|
Modifier and Type | Class and Description |
---|---|
static class |
PiEstimation.Sampler
Sampler randomly emits points that fall within a square of edge x * y.
|
static class |
PiEstimation.SumReducer
Simply sums up all long values.
|
Modifier and Type | Class and Description |
---|---|
static class |
EmptyFieldsCountAccumulator.EmptyFieldFilter
This function filters all incoming tuples that have one or more empty fields.
|
static class |
WebLogAnalysis.AntiJoinVisits
CoGroupFunction that realizes an anti-join.
|
static class |
WebLogAnalysis.FilterByRank
MapFunction that filters for records where the rank exceeds a certain threshold.
|
static class |
WebLogAnalysis.FilterDocByKeyWords
MapFunction that filters for documents that contain a certain set of keywords.
|
static class |
WebLogAnalysis.FilterVisitsByDate
MapFunction that filters for records of the visits relation where the year (from the date
string) is equal to a certain value.
|
Modifier and Type | Class and Description |
---|---|
static class |
WordCount.Tokenizer
Implements the string tokenizer that splits sentences into words as a user-defined
FlatMapFunction.
|
static class |
WordCountPojo.Tokenizer
Implements the string tokenizer that splits sentences into words as a user-defined
FlatMapFunction.
|
Modifier and Type | Interface and Description |
---|---|
interface |
EdgeJoinFunction<EV,T>
Interface to be implemented by the transformation function applied in
Graph.joinWithEdges(DataSet, EdgeJoinFunction) , Graph.joinWithEdgesOnSource(DataSet,
EdgeJoinFunction) , and Graph.joinWithEdgesOnTarget(DataSet, EdgeJoinFunction) methods. |
interface |
EdgesFunction<K,EV,O>
Interface to be implemented by the function applied to a vertex neighborhood in the
Graph.groupReduceOnEdges(EdgesFunction, EdgeDirection) method. |
interface |
EdgesFunctionWithVertexValue<K,VV,EV,O>
Interface to be implemented by the function applied to a vertex neighborhood in the
Graph.groupReduceOnEdges(EdgesFunctionWithVertexValue, EdgeDirection) method. |
interface |
NeighborsFunction<K,VV,EV,O>
Interface to be implemented by the function applied to a vertex neighborhood in the
Graph.groupReduceOnNeighbors(NeighborsFunction, EdgeDirection) method. |
interface |
NeighborsFunctionWithVertexValue<K,VV,EV,O>
Interface to be implemented by the function applied to a vertex neighborhood in the
Graph.groupReduceOnNeighbors(NeighborsFunctionWithVertexValue, EdgeDirection) method. |
interface |
ReduceEdgesFunction<EV>
Interface to be implemented by the function applied to a vertex neighborhood in the
Graph.reduceOnEdges(org.apache.flink.graph.ReduceEdgesFunction, EdgeDirection) method. |
interface |
ReduceNeighborsFunction<VV>
Interface to be implemented by the function applied to a vertex neighborhood in the
Graph.reduceOnNeighbors(ReduceNeighborsFunction, EdgeDirection) method. |
interface |
VertexJoinFunction<VV,T>
Interface to be implemented by the transformation function applied in
Graph.joinWithVertices(DataSet, VertexJoinFunction) method. |
Modifier and Type | Class and Description |
---|---|
static class |
DegreeAnnotationFunctions.DegreeCount<K>
Combines the vertex degree count.
|
static class |
DegreeAnnotationFunctions.JoinEdgeDegreeWithVertexDegree<K,EV,D>
Composes the vertex degree with this edge value.
|
static class |
DegreeAnnotationFunctions.JoinEdgeWithVertexDegree<K,EV,D>
Assigns the vertex degree to this edge value.
|
static class |
DegreeAnnotationFunctions.JoinVertexWithVertexDegree<K,VV>
Performs a left outer join to apply a zero count for vertices with out- or in-degree of zero.
|
static class |
DegreeAnnotationFunctions.MapEdgeToSourceId<K,EV>
Emits the source vertex ID along with an initial count.
|
static class |
DegreeAnnotationFunctions.MapEdgeToTargetId<K,EV>
Emits the target vertex ID along with an initial count.
|
Modifier and Type | Class and Description |
---|---|
static class |
BinaryResult.MirrorResult<T,RT extends BinaryResult<T>>
Output each input and a second result with the vertex order flipped.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TranslateFunction<T,O>
Base interface for Translate functions.
|
Modifier and Type | Class and Description |
---|---|
class |
RichTranslateFunction<IN,OUT>
Rich variant of the
TranslateFunction . |
Modifier and Type | Class and Description |
---|---|
class |
LongToLongValue
|
class |
LongValueAddOffset
Translate
LongValue by adding a constant offset value. |
class |
LongValueToSignedIntValue
|
class |
LongValueToStringValue
Translate
LongValue to StringValue . |
class |
LongValueToUnsignedIntValue
|
class |
ToNullValue<T>
Replace any type with
NullValue . |
Modifier and Type | Class and Description |
---|---|
class |
EdgeToTuple2Map<K,EV>
Create a Tuple2 DataSet from the vertices of an Edge DataSet.
|
class |
EdgeToTuple3Map<K,EV>
Create a Tuple3 DataSet from an Edge DataSet.
|
static class |
GraphUtils.AddLongValue
Add
LongValue elements. |
static class |
GraphUtils.IdentityMapper<T>
The identity mapper returns the input as output.
|
static class |
GraphUtils.MapTo<I,O>
Map each element to a value.
|
static class |
GraphUtils.NonForwardingIdentityMapper<T>
The identity mapper returns the input as output.
|
class |
Tuple2ToEdgeMap<K>
Create an Edge from a Tuple2.
|
class |
Tuple2ToVertexMap<K,VV>
Create a Vertex DataSet from a Tuple2 DataSet.
|
class |
Tuple3ToEdgeMap<K,EV>
Create an Edge DataSet from a Tuple3 DataSet.
|
class |
VertexToTuple2Map<K,VV>
Create a Tuple2 DataSet from a Vertex DataSet.
|
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 | Class and Description |
---|---|
class |
AbstractIterativeTask<S extends Function,OT>
The abstract base class for all tasks able to participate in an iteration.
|
class |
IterationHeadTask<X,Y,S extends Function,OT>
The head is responsible for coordinating an iteration and can run a
Driver inside. |
class |
IterationIntermediateTask<S extends Function,OT>
An intermediate iteration task, which runs a
Driver
inside. |
class |
IterationTailTask<S extends Function,OT>
An iteration tail, which runs a driver inside.
|
Modifier and Type | Class and Description |
---|---|
class |
BatchTask<S extends Function,OT>
The base class for all batch tasks.
|
interface |
Driver<S extends Function,OT>
The interface to be implemented by all drivers that run alone (or as the primary driver) in a
task.
|
interface |
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. |
Modifier and Type | Field and Description |
---|---|
protected S |
BatchTask.stub
The instantiated user code of this task's main operator (driver).
|
Modifier and Type | Method and Description |
---|---|
Function |
NoOpChainedDriver.getStub() |
Modifier and Type | Method and Description |
---|---|
Class<Function> |
UnionWithTempOperator.getStubType() |
Modifier and Type | Method and Description |
---|---|
static void |
BatchTask.closeUserCode(Function stub)
Closes the given stub using its
RichFunction.close() method. |
static void |
BatchTask.openUserCode(Function stub,
Configuration parameters)
Opens the given stub using its
RichFunction.open(Configuration) method. |
Modifier and Type | Method and Description |
---|---|
void |
UnionWithTempOperator.setup(TaskContext<Function,T> context) |
Modifier and Type | Method and Description |
---|---|
Function |
ChainedMapDriver.getStub() |
abstract Function |
ChainedDriver.getStub() |
Function |
SynchronousChainedCombineDriver.getStub() |
Function |
ChainedAllReduceDriver.getStub() |
Function |
ChainedReduceCombineDriver.getStub() |
Function |
ChainedFlatMapDriver.getStub() |
Modifier and Type | Class and Description |
---|---|
class |
AssignRangeIndex<IN>
This mapPartition function require a DataSet with RangeBoundaries as broadcast input, it generate
Tuple2 which includes range index and record itself as output.
|
class |
RangeBoundaryBuilder<T>
Build RangeBoundaries with input records.
|
class |
RemoveRangeIndex<T> |
Modifier and Type | Method and Description |
---|---|
<S extends Function,OT> |
TaskConfig.getDriver() |
Modifier and Type | Class and Description |
---|---|
static class |
StreamSQLTestProgram.Generator
Data-generating source function.
|
static class |
StreamSQLTestProgram.KillMapper
Kills the first execution attempt of an application when it receives the second record.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Timestamper<T>
Assigns an event time timestamp to the given record.
|
Modifier and Type | Class and Description |
---|---|
class |
BroadcastStateBootstrapFunction<IN>
Interface for writing elements to broadcast state.
|
class |
KeyedStateBootstrapFunction<K,IN>
A function that writes keyed state to a new operator.
|
class |
KeyedStateReaderFunction<K,OUT>
A function that processes keys from a restored operator
|
class |
StateBootstrapFunction<IN>
Interface for writing elements to operator state.
|
class |
WindowReaderFunction<IN,OUT,KEY,W extends Window>
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
Modifier and Type | Class and Description |
---|---|
class |
StateReaderOperator<F extends Function,KEY,N,OUT>
Base class for executing functions that read keyed state.
|
Modifier and Type | Field and Description |
---|---|
protected F |
StateReaderOperator.function |
Modifier and Type | Class and Description |
---|---|
class |
AggregateEvictingWindowReaderFunction<IN,ACC,R,OUT,KEY,W extends Window>
A wrapper for reading an evicting window operator with an aggregate function.
|
class |
EvictingWindowReaderFunction<IN,R,OUT,KEY,W extends Window>
Wrapper for reading state from an evicting window operator.
|
class |
PassThroughReader<KEY,W extends Window,IN>
A
WindowReaderFunction that just emits each input element. |
class |
ProcessEvictingWindowReader<IN,OUT,KEY,W extends Window>
A wrapper function for reading an evicting window with no pre-aggregation.
|
class |
ReduceEvictingWindowReaderFunction<IN,OUT,KEY,W extends Window>
A wrapper function for reading state from an evicting window operator with a reduce function.
|
Modifier and Type | Class and Description |
---|---|
class |
BoundedOneInputStreamTaskRunner<IN>
Deprecated.
|
class |
MergeOperatorStates
A reducer that aggregates multiple
OperatorState 's into a single CheckpointMetadata . |
class |
OperatorSubtaskStateReducer
A reducer that aggregates all
OperatorSubtaskState 's for a particular operator into a
single OperatorState . |
class |
StatePathExtractor
Extracts all file paths that are part of the provided
OperatorState . |
class |
TimestampAssignerWrapper<T>
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
HashSelector<IN>
Deprecated.
|
class |
KeyGroupRangePartitioner
Deprecated.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ExternallyInducedSource<T,CD>
Sources that implement this interface delay checkpoints when receiving a trigger message from the
checkpoint coordinator to the point when their input data/events indicate that a checkpoint
should be triggered.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AssignerWithPeriodicWatermarks<T>
Deprecated.
|
interface |
AssignerWithPunctuatedWatermarks<T>
Deprecated.
|
interface |
TimestampAssigner<T>
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
IngestionTimeExtractor<T>
Deprecated.
|
class |
KeyedProcessFunction<K,I,O>
A keyed function that processes elements of a stream.
|
class |
ProcessFunction<I,O>
A function that processes elements of a stream.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregationFunction<T>
Holder class for aggregation types that can be used on a windowed stream or keyed stream.
|
class |
ComparableAggregator<T>
An
AggregationFunction that computes values based on comparisons of Comparables . |
class |
SumAggregator<T>
An
AggregationFunction that sums up fields. |
Modifier and Type | Interface and Description |
---|---|
interface |
AsyncFunction<IN,OUT>
A function to trigger Async I/O operation.
|
Modifier and Type | Class and Description |
---|---|
class |
RichAsyncFunction<IN,OUT>
Rich variant of the
AsyncFunction . |
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.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseBroadcastProcessFunction
The base class containing the functionality available to all broadcast process function.
|
class |
BroadcastProcessFunction<IN1,IN2,OUT>
A function to be applied to a
BroadcastConnectedStream that
connects BroadcastStream , i.e. |
class |
CoProcessFunction<IN1,IN2,OUT>
A function that processes elements of two streams and produces a single output one.
|
class |
KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT>
A function to be applied to a
BroadcastConnectedStream that
connects BroadcastStream , i.e. |
class |
KeyedCoProcessFunction<K,IN1,IN2,OUT>
A function that processes elements of two keyed streams and produces a single output one.
|
class |
ProcessJoinFunction<IN1,IN2,OUT>
A function that processes two joined elements and produces a single output one.
|
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 |
KeyByKeySelector
KeyByKeySelector is responsible for extracting the first field of the input row as key. |
class |
PartitionCustomKeySelector
The
PartitionCustomKeySelector will return the first field of the input row value. |
Modifier and Type | Class and Description |
---|---|
class |
RemoveTimestampMapFunction<T>
MapFunction which removes the timestamp field from the input element.
|
Modifier and Type | Interface and Description |
---|---|
interface |
SinkFunction<IN>
Interface for implementing user defined sink functionality.
|
Modifier and Type | Class and Description |
---|---|
class |
DiscardingSink<T>
A stream sink that ignores all elements.
|
class |
OutputFormatSinkFunction<IN>
Deprecated.
Please use the
StreamingFileSink
for writing to files from a streaming program. |
class |
PrintSinkFunction<IN>
Implementation of the SinkFunction writing every tuple to the standard output or standard error
stream.
|
class |
RichSinkFunction<IN>
A
RichFunction version of SinkFunction . |
class |
SocketClientSink<IN>
Socket client that acts as a streaming sink.
|
class |
TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT>
This is a recommended base class for all of the
SinkFunction that intend to implement
exactly-once semantic. |
class |
WriteSinkFunction<IN>
Deprecated.
Please use the
StreamingFileSink
for writing to files from a streaming program. |
class |
WriteSinkFunctionByMillis<IN>
Deprecated.
Please use the
StreamingFileSink
for writing to files from a streaming program. |
Modifier and Type | Class and Description |
---|---|
class |
StreamingFileSink<IN>
Sink that emits its input elements to
FileSystem files within buckets. |
Modifier and Type | Interface and Description |
---|---|
interface |
ParallelSourceFunction<OUT>
A stream data source that is executed in parallel.
|
interface |
SourceFunction<T>
Base interface for all stream data sources in Flink.
|
Modifier and Type | Class and Description |
---|---|
class |
ContinuousFileMonitoringFunction<OUT>
This is the single (non-parallel) monitoring task which takes a
FileInputFormat and,
depending on the FileProcessingMode and the FilePathFilter , it is responsible
for:
Monitoring a user-provided path. |
class |
FileMonitoringFunction
Deprecated.
Internal class deprecated in favour of
ContinuousFileMonitoringFunction . |
class |
FileReadFunction
Deprecated.
Internal class deprecated in favour of
ContinuousFileMonitoringFunction . |
class |
FromElementsFunction<T>
A stream source function that returns a sequence of elements.
|
class |
FromIteratorFunction<T>
A
SourceFunction that reads elements from an Iterator and emits them. |
class |
FromSplittableIteratorFunction<T>
A
SourceFunction that reads elements from an SplittableIterator and emits them. |
class |
InputFormatSourceFunction<OUT>
A
SourceFunction that reads data using an InputFormat . |
class |
MessageAcknowledgingSourceBase<Type,UId>
Abstract base class for data sources that receive elements from a message queue and acknowledge
them back by IDs.
|
class |
MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId>
Abstract base class for data sources that receive elements from a message queue and acknowledge
them back by IDs.
|
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() . |
class |
SocketTextStreamFunction
A source function that reads strings from a socket.
|
class |
StatefulSequenceSource
A stateful streaming source that emits each number from a given interval exactly once, possibly
in parallel.
|
Modifier and Type | Class and Description |
---|---|
class |
DataGeneratorSource<T>
A data generator source that abstract data generator.
|
Modifier and Type | Class and Description |
---|---|
class |
AscendingTimestampExtractor<T>
Deprecated.
|
class |
BoundedOutOfOrdernessTimestampExtractor<T>
This is a
AssignerWithPeriodicWatermarks used to emit Watermarks that lag behind the
element with the maximum timestamp (in event time) seen so far by a fixed amount of time,
t_late . |
Modifier and Type | Interface and Description |
---|---|
interface |
AllWindowFunction<IN,OUT,W extends Window>
Base interface for functions that are evaluated over non-keyed windows.
|
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 |
AggregateApplyAllWindowFunction<W extends Window,T,ACC,V,R>
|
class |
AggregateApplyWindowFunction<K,W extends Window,T,ACC,V,R>
|
class |
PassThroughAllWindowFunction<W extends Window,T>
A
AllWindowFunction that just emits each input element. |
class |
PassThroughWindowFunction<K,W extends Window,T>
A
WindowFunction that just emits each input element. |
class |
ProcessAllWindowFunction<IN,OUT,W extends Window>
Base abstract class for functions that are evaluated over non-keyed windows using a context for
retrieving extra information.
|
class |
ProcessWindowFunction<IN,OUT,KEY,W extends Window>
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
class |
ReduceApplyAllWindowFunction<W extends Window,T,R>
Internal
AllWindowFunction that is used for implementing a fold on a window configuration
that only allows AllWindowFunction and cannot directly execute a ReduceFunction . |
class |
ReduceApplyProcessAllWindowFunction<W extends Window,T,R>
Internal
ProcessAllWindowFunction that is used for implementing a fold on a window
configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction . |
class |
ReduceApplyProcessWindowFunction<K,W extends Window,T,R>
Internal
ProcessWindowFunction that is used for implementing a fold on a window
configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction . |
class |
ReduceApplyWindowFunction<K,W extends Window,T,R>
Internal
WindowFunction that is used for implementing a fold on a window configuration
that only allows WindowFunction and cannot directly execute a ReduceFunction . |
class |
RichAllWindowFunction<IN,OUT,W extends Window>
A
RichFunction version of AllWindowFunction . |
class |
RichProcessAllWindowFunction<IN,OUT,W extends Window>
Deprecated.
use
ProcessAllWindowFunction instead |
class |
RichProcessWindowFunction<IN,OUT,KEY,W extends Window>
Deprecated.
use
ProcessWindowFunction instead |
class |
RichWindowFunction<IN,OUT,KEY,W extends Window>
Rich variant of the
WindowFunction . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractUdfStreamOperator<OUT,F extends Function>
This is used as the base class for operators that have a user-defined function.
|
Modifier and Type | Field and Description |
---|---|
protected F |
AbstractUdfStreamOperator.userFunction
The user function.
|
Modifier and Type | Method and Description |
---|---|
Function |
UdfStreamOperatorFactory.getUserFunction() |
Function |
SimpleUdfStreamOperatorFactory.getUserFunction() |
Modifier and Type | Class and Description |
---|---|
class |
CollectSinkFunction<IN>
A sink function that collects query results and sends them back to the client.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCassandraTupleSink<IN>
Abstract sink to write tuple-like values into a Cassandra cluster.
|
class |
CassandraPojoSink<IN>
Flink Sink to save data into a Cassandra cluster using Mapper,
which it uses annotations from
com.datastax.driver.mapping.annotations.
|
class |
CassandraRowSink
A SinkFunction to write Row records into a Cassandra table.
|
class |
CassandraScalaProductSink<IN extends scala.Product>
Sink to write scala tuples and case classes into a Cassandra cluster.
|
class |
CassandraSinkBase<IN,V>
CassandraSinkBase is the common abstract class of
CassandraPojoSink and CassandraTupleSink . |
class |
CassandraTupleSink<IN extends Tuple>
Sink to write Flink
Tuple s into a Cassandra cluster. |
Modifier and Type | Interface and Description |
---|---|
interface |
ElasticsearchSinkFunction<T>
Deprecated.
This has been deprecated and will be removed in the future.
|
Modifier and Type | Class and Description |
---|---|
class |
ElasticsearchSinkBase<T,C extends AutoCloseable>
Base class for all Flink Elasticsearch Sinks.
|
Modifier and Type | Class and Description |
---|---|
class |
ElasticsearchSink<T>
Deprecated.
This sink has been deprecated in favor of
ElasticsearchSink |
Modifier and Type | Class and Description |
---|---|
class |
PubSubSink<IN>
A sink function that outputs to PubSub.
|
class |
PubSubSource<OUT>
PubSub Source, this Source will consume PubSub messages from a subscription and Acknowledge them
on the next checkpoint.
|
Modifier and Type | Class and Description |
---|---|
class |
FlinkKafkaConsumer<T>
Deprecated.
|
class |
FlinkKafkaConsumerBase<T>
Base class of all Flink Kafka Consumer data sources.
|
class |
FlinkKafkaProducer<IN>
Deprecated.
Please use
KafkaSink . |
class |
FlinkKafkaProducerBase<IN>
Flink Sink to produce data into a Kafka topic.
|
Modifier and Type | Class and Description |
---|---|
class |
FlinkKafkaShuffleConsumer<T>
Flink Kafka Shuffle Consumer Function.
|
class |
FlinkKafkaShuffleProducer<IN,KEY>
Flink Kafka Shuffle Producer Function.
|
Modifier and Type | Class and Description |
---|---|
class |
FlinkDynamoDBStreamsConsumer<T>
Consume events from DynamoDB streams.
|
class |
FlinkKinesisConsumer<T>
The Flink Kinesis Consumer is an exactly-once parallel streaming data source that subscribes to
multiple AWS Kinesis streams within the same AWS service region, and can handle resharding of
streams.
|
class |
FlinkKinesisProducer<OUT>
Deprecated.
This producer based on the Kinesis Producer Library KPL has been superseded. The new
sink can be found in the module
flink-connectors/flink-connector-aws-kinesis-streams
and package KinesisStreamsSink . It is based on the AWS SDK for Java 2.x. The work to
replace this sink was carried out in FLINK-24227. |
Modifier and Type | Interface and Description |
---|---|
interface |
NiFiDataPacketBuilder<T>
A function that can create a NiFiDataPacket from an incoming instance of the given type.
|
Modifier and Type | Class and Description |
---|---|
class |
NiFiSink<T>
Deprecated.
The NiFi Sink has been deprecated and will be removed in a future Flink release.
|
class |
NiFiSource
Deprecated.
The NiFi Source has been deprecated and will be removed in a future Flink release.
|
Modifier and Type | Class and Description |
---|---|
class |
RMQSink<IN>
A Sink for publishing data into RabbitMQ.
|
class |
RMQSource<OUT>
RabbitMQ source (consumer) which reads from a queue and acknowledges messages on checkpoints.
|
Modifier and Type | Class and Description |
---|---|
class |
WikipediaEditsSource
This class is a SourceFunction that reads
WikipediaEditEvent instances from the IRC
channel #en.wikipedia . |
Modifier and Type | Class and Description |
---|---|
class |
SimpleSource
A checkpointed source.
|
Modifier and Type | Class and Description |
---|---|
static class |
IterateExample.InputMap
Map the inputs so that the next Fibonacci numbers can be calculated while preserving the
original input tuple.
|
static class |
IterateExample.OutputMap
Giving back the input pair and the counter.
|
static class |
IterateExample.Step
Iteration step function that calculates the next Fibonacci number.
|
Modifier and Type | Class and Description |
---|---|
static class |
SideOutputExample.Tokenizer
Implements the string tokenizer that splits sentences into words as a user-defined
FlatMapFunction.
|
Modifier and Type | Class and Description |
---|---|
class |
EventsGeneratorSource
A event stream source that generates the events on the fly.
|
Modifier and Type | Class and Description |
---|---|
class |
CarSource
A simple in-memory source.
|
Modifier and Type | Class and Description |
---|---|
class |
CollectSink<IN>
A specialized data sink to be used by DataStreamUtils.collect().
|
Modifier and Type | Class and Description |
---|---|
class |
CustomWatermarkExtractor
A custom
AssignerWithPeriodicWatermarks , that simply assumes that the input stream
records are strictly ascending. |
class |
RollingAdditionMapper
A
RichMapFunction that continuously outputs the current total frequency count of a key. |
Modifier and Type | Method and Description |
---|---|
String |
WindowOperatorBuilder.generateOperatorDescription(Function function1,
Function function2) |
Modifier and Type | Interface and Description |
---|---|
interface |
InternalWindowFunction<IN,OUT,KEY,W extends Window>
Internal interface for functions that are evaluated over keyed (grouped) windows.
|
Modifier and Type | Class and Description |
---|---|
class |
InternalAggregateProcessAllWindowFunction<T,ACC,V,R,W extends Window>
Internal window function for wrapping a
ProcessAllWindowFunction that takes an Iterable and an AggregateFunction . |
class |
InternalAggregateProcessWindowFunction<T,ACC,V,R,K,W extends Window>
Internal window function for wrapping a
ProcessWindowFunction that takes an Iterable and an AggregateFunction . |
class |
InternalIterableAllWindowFunction<IN,OUT,W extends Window>
Internal window function for wrapping an
AllWindowFunction that takes an Iterable
when the window state also is an Iterable . |
class |
InternalIterableProcessAllWindowFunction<IN,OUT,W extends Window>
Internal window function for wrapping a
ProcessAllWindowFunction that takes an Iterable when the window state also is an Iterable . |
class |
InternalIterableProcessWindowFunction<IN,OUT,KEY,W extends Window>
Internal window function for wrapping a
ProcessWindowFunction that takes an Iterable when the window state also is an Iterable . |
class |
InternalIterableWindowFunction<IN,OUT,KEY,W extends Window>
Internal window function for wrapping a
WindowFunction that takes an Iterable
when the window state also is an Iterable . |
class |
InternalSingleValueAllWindowFunction<IN,OUT,W extends Window>
Internal window function for wrapping an
AllWindowFunction that takes an Iterable
when the window state is a single value. |
class |
InternalSingleValueProcessAllWindowFunction<IN,OUT,W extends Window>
Internal window function for wrapping a
ProcessAllWindowFunction that takes an Iterable when the window state is a single value. |
class |
InternalSingleValueProcessWindowFunction<IN,OUT,KEY,W extends Window>
Internal window function for wrapping a
ProcessWindowFunction that takes an Iterable when the window state is a single value. |
class |
InternalSingleValueWindowFunction<IN,OUT,KEY,W extends Window>
Internal window function for wrapping a
WindowFunction that takes an Iterable
when the window state is a single value. |
Modifier and Type | Class and Description |
---|---|
class |
FailureMapper<T>
This mapper simulates failure by throwing exceptions.
|
static class |
PeriodicStreamingJob.PeriodicSourceGenerator
Data-generating source function.
|
class |
SemanticsCheckMapper
This mapper validates exactly-once and at-least-once semantics in connection with
SequenceGeneratorSource . |
class |
SequenceGeneratorSource
This source function generates a sequence of long values per key.
|
class |
SlidingWindowCheckMapper
This mapper validates sliding event time window.
|
Modifier and Type | Class and Description |
---|---|
class |
ArtificalOperatorStateMapper<IN,OUT>
A self-verifiable
RichMapFunction used to verify checkpointing and restore semantics for
various kinds of operator state. |
class |
ArtificialKeyedStateMapper<IN,OUT>
A generic, stateful
MapFunction that allows specifying what states to maintain based on a
provided list of ArtificialStateBuilder s. |
Modifier and Type | Class and Description |
---|---|
class |
FiniteTestSource<T>
A stream source that: 1) emits a list of elements without allowing checkpoints, 2) then waits for
two more checkpoints to complete, 3) then re-emits the same elements before 4) waiting for
another two checkpoints and 5) exiting.
|
Modifier and Type | Method and Description |
---|---|
static void |
StreamingFunctionUtils.restoreFunctionState(StateInitializationContext context,
Function userFunction) |
static <T> void |
StreamingFunctionUtils.setOutputType(Function userFunction,
TypeInformation<T> outTypeInfo,
ExecutionConfig executionConfig) |
static void |
StreamingFunctionUtils.snapshotFunctionState(StateSnapshotContext context,
OperatorStateBackend backend,
Function userFunction) |
Modifier and Type | Class and Description |
---|---|
static class |
KeySelectorUtil.ArrayKeySelector<IN>
A key selector for selecting individual array fields as keys and returns them as a Tuple.
|
static class |
KeySelectorUtil.ComparableKeySelector<IN>
A key selector for selecting key fields via a TypeComparator.
|
static class |
KeySelectorUtil.OneKeySelector<IN,K>
Key extractor that extracts a single field via a generic comparator.
|
Modifier and Type | Class and Description |
---|---|
class |
SocketSourceFunction
The
SocketSourceFunction opens a socket and consumes bytes. |
Modifier and Type | Class and Description |
---|---|
class |
ArrowSourceFunction
An Arrow
SourceFunction which takes the serialized arrow record batch data as input. |
Modifier and Type | Class and Description |
---|---|
class |
TableFunctionCollector<T>
The basic implementation of collector for
TableFunction . |
class |
TableFunctionResultFuture<T>
The basic implementation of collector for
ResultFuture in table joining. |
class |
WrappingCollector<T>
A
Collector that wraps another collector. |
Modifier and Type | Class and Description |
---|---|
class |
KeyedProcessFunctionWithCleanupState<K,IN,OUT>
A function that processes elements of a stream, and could cleanup state.
|
Modifier and Type | Class and Description |
---|---|
class |
GeneratedFunction<F extends Function>
Describes a generated
Function . |
Modifier and Type | Interface and Description |
---|---|
interface |
AggsHandleFunction
The base class for handling aggregate functions.
|
interface |
AggsHandleFunctionBase
The base class for handling aggregate or table aggregate functions.
|
interface |
JoinCondition
Interface for code generated condition function for [[org.apache.calcite.rel.core.Join]].
|
interface |
NamespaceAggsHandleFunction<N>
The base class for handling aggregate functions with namespace.
|
interface |
NamespaceAggsHandleFunctionBase<N>
The base class for handling aggregate or table aggregate functions.
|
interface |
NamespaceTableAggsHandleFunction<N>
The base class for handling table aggregate functions with namespace.
|
interface |
TableAggsHandleFunction
The base class for handling table aggregate functions.
|
Modifier and Type | Class and Description |
---|---|
class |
WatermarkGenerator
The
WatermarkGenerator is used to generate watermark based the input elements. |
Modifier and Type | Interface and Description |
---|---|
interface |
RowDataKeySelector
RowDataKeySelector takes an RowData and extracts the deterministic key for the RowData.
|
Modifier and Type | Class and Description |
---|---|
class |
BinaryRowDataKeySelector
A KeySelector which will extract key from RowData.
|
class |
EmptyRowDataKeySelector
A utility class which key is always empty no matter what the input row is.
|
Modifier and Type | Class and Description |
---|---|
class |
GroupAggFunction
Aggregate Function used for the groupby (without window) aggregate.
|
class |
GroupTableAggFunction
Aggregate Function used for the groupby (without window) table aggregate.
|
class |
MiniBatchGlobalGroupAggFunction
Aggregate Function used for the global groupby (without window) aggregate in miniBatch mode.
|
class |
MiniBatchGroupAggFunction
Aggregate Function used for the groupby (without window) aggregate in miniBatch mode.
|
class |
MiniBatchIncrementalGroupAggFunction
Aggregate Function used for the incremental groupby (without window) aggregate in miniBatch mode.
|
class |
MiniBatchLocalGroupAggFunction
Aggregate Function used for the local groupby (without window) aggregate in miniBatch mode.
|
Modifier and Type | Class and Description |
---|---|
class |
MapBundleFunction<K,V,IN,OUT>
Basic interface for map bundle processing.
|
Modifier and Type | Class and Description |
---|---|
class |
ProcTimeDeduplicateKeepFirstRowFunction
This function is used to deduplicate on keys and keeps only first row.
|
class |
ProcTimeDeduplicateKeepLastRowFunction
This function is used to deduplicate on keys and keeps only last row.
|
class |
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction
This function is used to get the first row for every key partition in miniBatch mode.
|
class |
ProcTimeMiniBatchDeduplicateKeepLastRowFunction
This function is used to get the last row for every key partition in miniBatch mode.
|
class |
RowTimeDeduplicateFunction
This function is used to deduplicate on keys and keeps only first or last row on row time.
|
class |
RowTimeMiniBatchDeduplicateFunction
This function is used to get the first or last row for every key partition in miniBatch mode.
|
class |
RowTimeMiniBatchLatestChangeDeduplicateFunction
This function is used to get the first or last row for every key partition in miniBatch mode.
|
Modifier and Type | Class and Description |
---|---|
class |
JoinConditionWithNullFilters
Utility to take null filters into consideration when apply join condition.
|
Modifier and Type | Class and Description |
---|---|
class |
FilterAllFlatMapFunction
Function filtering out all the input records.
|
class |
IntervalJoinFunction
|
class |
PaddingLeftMapFunction
Function performing left padding.
|
class |
PaddingRightMapFunction
Function performing right padding.
|
class |
ProcTimeIntervalJoin
The function to execute processing time interval stream inner-join.
|
class |
RowTimeIntervalJoin
The function to execute row(event) time interval stream inner-join.
|
Modifier and Type | Class and Description |
---|---|
class |
AsyncLookupJoinRunner
The async join runner to lookup the dimension table.
|
class |
AsyncLookupJoinWithCalcRunner
The async join runner with an additional calculate function on the dimension table.
|
class |
LookupJoinRunner
The join runner to lookup the dimension table.
|
class |
LookupJoinWithCalcRunner
The join runner with an additional calculate function on the dimension table.
|
Modifier and Type | Class and Description |
---|---|
class |
IterativeConditionRunner
A
RichIterativeCondition wrapper to delegate invocation to the code generated RichIterativeCondition . |
class |
PatternProcessFunctionRunner
A
PatternProcessFunction wrapper to delegate invocation to the code generated PatternProcessFunction . |
Modifier and Type | Class and Description |
---|---|
class |
DropUpdateBeforeFunction
A function drops only rows with
RowKind.UPDATE_BEFORE changelog kind. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRowTimeUnboundedPrecedingOver<K>
A basic implementation to support unbounded event-time over-window.
|
class |
ProcTimeRangeBoundedPrecedingFunction<K>
Process Function used for the aggregate in bounded proc-time OVER window.
|
class |
ProcTimeRowsBoundedPrecedingFunction<K>
Process Function for ROW clause processing-time bounded OVER window.
|
class |
ProcTimeUnboundedPrecedingFunction<K>
Process Function for processing-time unbounded OVER window.
|
class |
RowTimeRangeBoundedPrecedingFunction<K>
Process Function for RANGE clause event-time bounded OVER window.
|
class |
RowTimeRangeUnboundedPrecedingFunction<K>
A ProcessFunction to support unbounded RANGE window.
|
class |
RowTimeRowsBoundedPrecedingFunction<K>
Process Function for ROWS clause event-time bounded OVER window.
|
class |
RowTimeRowsUnboundedPrecedingFunction<K>
A ProcessFunction to support unbounded ROWS window.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractTopNFunction
Base class for TopN Function.
|
class |
AppendOnlyFirstNFunction
A variant of
AppendOnlyTopNFunction to handle first-n case. |
class |
AppendOnlyTopNFunction
A TopN function could handle insert-only stream.
|
class |
FastTop1Function
A more concise implementation for
AppendOnlyTopNFunction and UpdatableTopNFunction when only Top-1 is desired. |
class |
RetractableTopNFunction
A TopN function could handle updating stream.
|
class |
UpdatableTopNFunction
A TopN function could handle updating stream.
|
Modifier and Type | Class and Description |
---|---|
class |
BoundedOutOfOrderWatermarkGenerator
A watermark generator for rowtime attributes which are out-of-order by a bounded time interval.
|
class |
PeriodicWatermarkAssignerWrapper
Generates periodic watermarks based on a
PeriodicWatermarkAssigner . |
class |
PunctuatedWatermarkAssignerWrapper
Generates periodic watermarks based on a
PunctuatedWatermarkAssigner . |
Modifier and Type | Class and Description |
---|---|
static class |
CsvTableSink.CsvFormatter
Deprecated.
Formats a Row into a String with fields separated by the field delimiter.
|
Modifier and Type | Class and Description |
---|---|
static class |
StatefulStreamingJob.MySource
Stub source that emits one record per second.
|
static class |
StatefulStreamingJob.MyStatefulFunction
A stateful
RichMapFunction that keeps the required types of state. |
Modifier and Type | Class and Description |
---|---|
class |
AlertSink
A sink for outputting alerts.
|
Modifier and Type | Class and Description |
---|---|
class |
TransactionSource
A stream of transactions.
|
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.