Modifier and Type | Class and Description |
---|---|
class |
ProcedureNamespace
Namespace whose contents are defined by the result of a call to a user-defined procedure.
|
Modifier and Type | Class and Description |
---|---|
interface |
VisibleForTesting
This annotations declares that a function, field, constructor, or entire type, is only visible
for testing purposes.
|
Modifier and Type | Class and Description |
---|---|
interface |
ConfigGroup
A class that specifies a group of config options.
|
interface |
ConfigGroups
Annotation used on classes containing config options that enables the separation of options into
different tables based on key prefixes.
|
static interface |
Documentation.ExcludeFromDocumentation
Annotation used on config option fields or REST API message headers to exclude it from
documentation.
|
static interface |
Documentation.OverrideDefault
Annotation used on config option fields to override the documented default.
|
static interface |
Documentation.Section
Annotation used on config option fields to include them in specific sections.
|
static interface |
Documentation.SuffixOption
Annotation used on config option fields or options class to mark them as a suffix-option;
i.e., a config option where the key is only a suffix, with the prefix being dynamically
provided at runtime.
|
static interface |
Documentation.TableOption
Annotation used on table config options for adding meta data labels.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Archiveable<T extends Serializable> |
class |
ArchivedExecutionConfig
Serializable class which is created when archiving the job.
|
class |
Plan
This class represents Flink programs, in the form of dataflow plans.
|
class |
TaskInfo
Encapsulates task-specific information: name, index of subtask, parallelism and attempt number.
|
Modifier and Type | Method and Description |
---|---|
ArchivedExecutionConfig |
ExecutionConfig.archive() |
boolean |
ExecutionConfig.isLatencyTrackingConfigured() |
Modifier and Type | Class and Description |
---|---|
class |
AccumulatorHelper
Helper functions for the interaction with
Accumulator . |
Modifier and Type | Class and Description |
---|---|
class |
AggregatorRegistry
A registry for iteration
Aggregator s. |
Modifier and Type | Class and Description |
---|---|
class |
CommonRangeBoundaries<T> |
Modifier and Type | Class and Description |
---|---|
class |
WatermarkOutputMultiplexer
A
WatermarkOutputMultiplexer combines the watermark (and idleness) updates of multiple
partitions/shards/splits into one combined watermark update and forwards it to an underlying
WatermarkOutput . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRuntimeUDFContext
A standalone implementation of the
RuntimeContext , created by runtime UDF operators. |
class |
CopyingIterator<E>
Wraps an iterator to return deep copies of the original iterator's elements.
|
class |
CopyingListCollector<T>
A
Collector that collects deep copies of its elements in a list. |
class |
FunctionUtils
Utility class that contains helper methods to work with Flink
Function class. |
class |
ListCollector<T>
A
Collector that puts the collected elements into a given list. |
class |
NoOpFunction
An
AbstractRichFunction that does nothing. |
class |
PrintSinkOutputWriter<IN>
Print sink output writer for DataStream and DataSet print API.
|
class |
RuntimeUDFContext
A standalone implementation of the
RuntimeContext , created by runtime UDF operators. |
Modifier and Type | Method and Description |
---|---|
String |
AbstractRuntimeUDFContext.getAllocationIDAsString() |
Modifier and Type | Class and Description |
---|---|
class |
DefaultInputSplitAssigner
This is the default implementation of the
InputSplitAssigner interface. |
class |
GenericCsvInputFormat<OT> |
class |
GlobFilePathFilter
Class for determining if a particular file should be included or excluded based on a set of
include and exclude glob filters.
|
class |
ReplicatingInputSplitAssigner
Assigns each InputSplit to each requesting parallel instance.
|
Modifier and Type | Class and Description |
---|---|
class |
Bzip2InputStreamFactory
Factory for Bzip2 decompressors.
|
class |
DeflateInflaterInputStreamFactory
Factory for input streams that decompress the "deflate" compression format.
|
class |
GzipInflaterInputStreamFactory
Factory for input streams that decompress the GZIP compression format.
|
interface |
InflaterInputStreamFactory<T extends InputStream>
Creates a new instance of a certain subclass of
InflaterInputStream . |
class |
XZInputStreamFactory
Factory for XZ decompressors.
|
class |
ZStandardInputStreamFactory
Factory for ZStandard decompressors.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractUdfOperator<OUT,FT extends Function>
Abstract superclass for all contracts that represent actual operators.
|
class |
BinaryOperatorInformation<IN1,IN2,OUT>
A class for holding information about a single input operator, such as input/output
TypeInformation.
|
class |
CollectionExecutor
Execution utility for serial, local, collection-based executions of Flink programs.
|
class |
CompilerHints
A class encapsulating compiler hints describing the behavior of the user function.
|
class |
DualInputOperator<IN1,IN2,OUT,FT extends Function>
Abstract operator superclass for all operators that have two inputs, like "Join", "CoGroup", or
"Cross".
|
class |
DualInputSemanticProperties
Container for the semantic properties associated to a dual input operator.
|
class |
GenericDataSinkBase<IN>
Operator for nodes that act as data sinks, storing the data they receive.
|
class |
GenericDataSourceBase<OUT,T extends InputFormat<OUT,?>>
Abstract superclass for data sources in a Pact plan.
|
interface |
IterationOperator |
class |
Keys<T> |
class |
Operator<OUT>
Abstract base class for all operators.
|
class |
OperatorInformation<OUT>
A class for holding information about an operator, such as input/output TypeInformation.
|
class |
Ordering
This class represents an ordering on a set of fields.
|
class |
ResourceSpec
Describe the different resource factors of the operator with UDF.
|
interface |
SemanticProperties
Container for the semantic properties associated to an operator.
|
class |
SingleInputOperator<IN,OUT,FT extends Function>
Abstract superclass for for all operators that have one input like "map" or "reduce".
|
class |
SingleInputSemanticProperties
Container for the semantic properties associated to a single input operator.
|
class |
UnaryOperatorInformation<IN,OUT>
A class for holding information about a single input operator, such as input/output
TypeInformation.
|
class |
Union<T>
This operator represents a Union between two inputs.
|
Modifier and Type | Class and Description |
---|---|
class |
BulkIterationBase<T> |
class |
CoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> |
class |
CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> |
class |
CrossOperatorBase<IN1,IN2,OUT,FT extends CrossFunction<IN1,IN2,OUT>> |
class |
DeltaIterationBase<ST,WT>
A DeltaIteration is similar to a
BulkIterationBase , but maintains state across the
individual iteration steps. |
class |
FilterOperatorBase<T,FT extends FlatMapFunction<T,T>> |
class |
FlatMapOperatorBase<IN,OUT,FT extends FlatMapFunction<IN,OUT>> |
class |
GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>>
Base operator for the combineGroup transformation.
|
class |
GroupReduceOperatorBase<IN,OUT,FT extends GroupReduceFunction<IN,OUT>> |
class |
InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
class |
JoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
class |
MapOperatorBase<IN,OUT,FT extends MapFunction<IN,OUT>> |
class |
MapPartitionOperatorBase<IN,OUT,FT extends MapPartitionFunction<IN,OUT>> |
class |
OuterJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
class |
PartitionOperatorBase<IN> |
class |
ReduceOperatorBase<T,FT extends ReduceFunction<T>>
Base data flow operator for Reduce user-defined functions.
|
class |
SortPartitionOperatorBase<IN> |
Modifier and Type | Class and Description |
---|---|
class |
FieldList
Immutable ordered list of fields IDs.
|
class |
FieldSet
Immutable unordered collection of fields IDs.
|
class |
JoinHashMap<BT> |
class |
ListKeyGroupedIterator<E>
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
|
class |
TypeComparable<T>
Wrapper that is used to store elements for which we have a TypeComparator in a Hash Map.
|
class |
UserCodeClassWrapper<T>
This holds a class containing user defined code.
|
class |
UserCodeObjectWrapper<T>
This holds an actual object containing user defined code.
|
interface |
UserCodeWrapper<T>
UDf operators can have either a class or an object containing the user code, this is the common
interface to access them.
|
Modifier and Type | Class and Description |
---|---|
class |
CPUResource
Represents CPU resource.
|
class |
ExternalResource
An external resource.
|
class |
Resource<T extends Resource<T>>
Base class for resources one can specify.
|
Modifier and Type | Class and Description |
---|---|
class |
RuntimeContextInitializationContextAdapters
A set of adapters between
RuntimeContext and DeserializationSchema.InitializationContext or SerializationSchema.InitializationContext . |
Modifier and Type | Method and Description |
---|---|
StateTtlConfig |
StateDescriptor.getTtlConfig() |
Modifier and Type | Class and Description |
---|---|
class |
Deadline
This class stores a deadline, as obtained via
Deadline.now() or from Deadline.plus(Duration) . |
Modifier and Type | Class and Description |
---|---|
class |
BackwardsCompatibleSerializerSnapshot<T>
A utility
TypeSerializerConfigSnapshot that is used for backwards compatibility purposes. |
class |
CompositeTypeSerializerConfigSnapshot<T>
A
TypeSerializerConfigSnapshot for serializers that has multiple nested serializers. |
class |
CompositeTypeSerializerUtil
Utilities for the
CompositeTypeSerializerSnapshot . |
class |
GenericPairComparator<T1,T2> |
class |
GenericTypeSerializerConfigSnapshot<T>
Configuration snapshot for serializers for generic types.
|
class |
GenericTypeSerializerSnapshot<T,S extends TypeSerializer>
Base
TypeSerializerSnapshot for serializers for generic types. |
interface |
LegacySerializerSnapshotTransformer<T>
This interface provides a way for
TypeSerializer s to transform a legacy TypeSerializerSnapshot used in versions before Flink 1.7 during deserialization. |
class |
NestedSerializersSnapshotDelegate
A NestedSerializersSnapshotDelegate represents the snapshots of multiple serializers that are
used by an outer serializer.
|
class |
ParameterlessTypeSerializerConfig<T>
Deprecated.
this snapshot class is no longer used by any serializers, and is maintained only for
backward compatibility reasons. It is fully replaced by
SimpleTypeSerializerSnapshot . |
class |
SameTypePairComparator<T> |
class |
SingleThreadAccessCheckingTypeSerializer<T> |
interface |
TypeComparatorFactory<T> |
class |
TypePairComparator<T1,T2>
This interface defines the method required by the runtime to use data types in join-like
operations.
|
interface |
TypePairComparatorFactory<T1,T2> |
static interface |
TypeSerializerConfigSnapshot.SelfResolvingTypeSerializer<E>
Deprecated.
This interface assists with the migration path to the new serialization abstraction.
|
interface |
TypeSerializerFactory<T> |
class |
TypeSerializerSerializationUtil
Deprecated.
This utility class was used to write serializers into checkpoints. Starting from
Flink 1.6.x, this should no longer happen, and therefore this class is deprecated. It remains
here for backwards compatibility paths.
|
Modifier and Type | Method and Description |
---|---|
ClassLoader |
TypeSerializerConfigSnapshot.getUserCodeClassLoader()
Deprecated.
Returns the user code class loader.
|
void |
TypeSerializerConfigSnapshot.setPriorSerializer(TypeSerializer<T> serializer)
Deprecated.
Set the originating serializer of this configuration snapshot.
|
void |
TypeSerializerConfigSnapshot.setUserCodeClassLoader(ClassLoader userCodeClassLoader)
Deprecated.
Set the user code class loader.
|
Modifier and Type | Class and Description |
---|---|
class |
BasicTypeComparator<T extends Comparable<T>> |
class |
BigDecComparator
Comparator for comparing BigDecimal values.
|
class |
BigDecSerializer
Serializer for serializing/deserializing BigDecimal values including null values.
|
class |
BigIntComparator
Comparator for comparing BigInteger values.
|
class |
BigIntSerializer
Serializer for serializing/deserializing BigInteger values including null values.
|
class |
BooleanComparator |
class |
BooleanSerializer
Type serializer for
Boolean . |
class |
BooleanValueComparator
Specialized comparator for BooleanValue based on CopyableValueComparator.
|
class |
BooleanValueSerializer |
class |
ByteComparator |
class |
ByteSerializer
Type serializer for
Byte . |
class |
ByteValueComparator
Specialized comparator for ByteValue based on CopyableValueComparator.
|
class |
ByteValueSerializer |
class |
CharComparator |
class |
CharSerializer
Type serializer for
Character . |
class |
CharValueComparator
Specialized comparator for CharValue based on CopyableValueComparator.
|
class |
CharValueSerializer |
class |
CollectionSerializerConfigSnapshot<C extends Collection<T>,T>
Deprecated.
this snapshot class should no longer be used by any serializers as their snapshot.
|
class |
DateComparator |
class |
DateSerializer |
class |
DoubleComparator |
class |
DoubleSerializer
Type serializer for
Double . |
class |
DoubleValueComparator
Specialized comparator for DoubleValue based on CopyableValueComparator.
|
class |
DoubleValueSerializer |
class |
EnumComparator<T extends Enum<T>> |
class |
EnumSerializer<T extends Enum<T>>
TypeSerializer for Java enums. |
class |
FloatComparator |
class |
FloatSerializer
Type serializer for
Float . |
class |
FloatValueComparator
Specialized comparator for FloatValue based on CopyableValueComparator.
|
class |
FloatValueSerializer |
class |
GenericArraySerializer<C>
A serializer for arrays of objects.
|
class |
GenericArraySerializerConfigSnapshot<C>
Deprecated.
this is deprecated and no longer used by the
GenericArraySerializer . It has
been replaced by GenericArraySerializerSnapshot . |
class |
InstantComparator
Comparator for comparing Java Instant.
|
class |
InstantSerializer
Serializer for serializing/deserializing Instant values including null values.
|
class |
IntComparator |
class |
IntSerializer
Type serializer for
Integer (and int , via auto-boxing). |
class |
IntValueComparator
Specialized comparator for IntValue based on CopyableValueComparator.
|
class |
IntValueSerializer |
class |
ListSerializer<T>
A serializer for
Lists . |
class |
LocalDateComparator
This class can not extend
BasicTypeComparator , because LocalDate is a Comparable of
ChronoLocalDate instead of Comparable of LocalDate. |
class |
LocalDateSerializer |
class |
LocalDateTimeComparator
This class can not extend
BasicTypeComparator , because LocalDateTime is a Comparable of
ChronoLocalDateTime instead of Comparable of LocalDateTime. |
class |
LocalDateTimeSerializer |
class |
LocalTimeComparator |
class |
LocalTimeSerializer |
class |
LongComparator |
class |
LongSerializer
Type serializer for
Long . |
class |
LongValueComparator
Specialized comparator for LongValue based on CopyableValueComparator.
|
class |
LongValueSerializer |
class |
MapSerializer<K,V>
A serializer for
Map . |
class |
MapSerializerConfigSnapshot<K,V>
Deprecated.
this snapshot class should not be used by any serializer anymore.
|
class |
NormalizedKeyUtil
Utilities related to
TypeComparator . |
class |
NullValueComparator
Specialized comparator for NullValue based on CopyableValueComparator.
|
class |
NullValueSerializer |
class |
ShortComparator |
class |
ShortSerializer
Type serializer for
Byte . |
class |
ShortValueComparator
Specialized comparator for ShortValue based on CopyableValueComparator.
|
class |
ShortValueSerializer |
class |
SqlDateSerializer |
class |
SqlTimeSerializer |
class |
SqlTimestampComparator
Comparator for comparing Java SQL Timestamps.
|
class |
SqlTimestampSerializer |
class |
StringComparator |
class |
StringSerializer
Type serializer for
String . |
class |
StringValueComparator
Specialized comparator for StringValue based on CopyableValueComparator.
|
class |
StringValueSerializer |
class |
TypeSerializerSingleton<T> |
class |
VoidSerializer
Serializer for
Void . |
Modifier and Type | Interface and Description |
---|---|
interface |
Pipeline
Common interface for Flink pipelines.
|
class |
Transformation<T>
A
Transformation represents the operation that creates a DataStream. |
Modifier and Type | Class and Description |
---|---|
class |
ClosureCleaner
The closure cleaner is a utility that tries to truncate the closure (enclosing instance) of
non-static inner classes (created for inline transformation functions).
|
class |
ExecutionPlanUtil
A utility for extracting an execution plan (as JSON) from a
Plan . |
static interface |
ExecutionPlanUtil.ExecutionPlanJSONGenerator
Internal interface for the JSON plan generator that has to reside in the optimizer package.
|
class |
RemoteEnvironmentConfigUtils
A set of tools used by batch and streaming remote environments when preparing their
configurations.
|
class |
ScalaShellEnvironment
Special version of
ExecutionEnvironment that has a reference to
a FlinkILoop . |
class |
ScalaShellStreamEnvironment
A
StreamExecutionEnvironment for the Scala shell. |
class |
Utils
Utility class that contains helper methods to work with Java APIs.
|
Modifier and Type | Method and Description |
---|---|
static boolean |
ExecutionEnvironment.areExplicitEnvironmentsAllowed()
Checks whether it is currently permitted to explicitly instantiate a LocalEnvironment or a
RemoteEnvironment.
|
Plan |
ExecutionEnvironment.createProgramPlan()
Creates the program's
Plan . |
Plan |
ExecutionEnvironment.createProgramPlan(String jobName)
Creates the program's
Plan . |
Plan |
ExecutionEnvironment.createProgramPlan(String jobName,
boolean clearSinks)
Creates the program's
Plan . |
Configuration |
ExecutionEnvironment.getConfiguration() |
PipelineExecutorServiceLoader |
ExecutionEnvironment.getExecutorServiceLoader() |
ClassLoader |
ExecutionEnvironment.getUserCodeClassLoader() |
Modifier and Type | Class and Description |
---|---|
class |
AggregationFunction<T> |
interface |
AggregationFunctionFactory
Interface of factory for creating
AggregationFunction . |
class |
MaxAggregationFunction<T extends Comparable<T>>
Implementation of
AggregationFunction for max operation. |
class |
MinAggregationFunction<T extends Comparable<T>>
Implementations of
AggregationFunction for min operation. |
class |
SumAggregationFunction<T>
Definitions of sum functions for different numerical types.
|
Modifier and Type | Class and Description |
---|---|
class |
FirstReducer<T>
Reducer that only emits the first N elements in a group.
|
class |
FormattingMapper<T>
Mapper that converts values to strings using a
TextOutputFormat.TextFormatter . |
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.
|
class |
SemanticPropUtil
Utility class that contains helper methods to work with
SemanticProperties . |
Modifier and Type | Method and Description |
---|---|
static Set<Annotation> |
FunctionAnnotation.readDualForwardAnnotations(Class<?> udfClass)
Reads the annotations of a user defined function with two inputs and returns semantic
properties according to the forwarded fields annotated.
|
static Set<Annotation> |
FunctionAnnotation.readSingleForwardAnnotations(Class<?> udfClass)
Reads the annotations of a user defined function with one input and returns semantic
properties according to the forwarded fields annotated.
|
Modifier and Type | Class and Description |
---|---|
class |
HadoopInputFormatCommonBase<T,SPITTYPE extends InputSplit>
A common base for both "mapred" and "mapreduce" Hadoop input formats.
|
class |
HadoopOutputFormatCommonBase<T>
A common base for both "mapred" and "mapreduce" Hadoop output formats.
|
Modifier and Type | Class and Description |
---|---|
class |
HadoopInputFormatBase<K,V,T>
Common base for Java and Scala API for using Hadoop input formats with Flink.
|
class |
HadoopOutputFormatBase<K,V,T>
Common base for the mapred HadoopOutputFormat wrappers.
|
Modifier and Type | Class and Description |
---|---|
class |
HadoopUtils
Utility class to work with Apache Hadoop MapRed classes.
|
Modifier and Type | Class and Description |
---|---|
class |
HadoopInputSplit
A wrapper that represents an input split from the Hadoop mapred API as a Flink
InputSplit . |
Modifier and Type | Class and Description |
---|---|
class |
HadoopInputFormatBase<K,V,T>
Base class shared between the Java and Scala API of Flink.
|
class |
HadoopOutputFormatBase<K,V,T>
Base class shared between the Java and Scala API of Flink.
|
Modifier and Type | Class and Description |
---|---|
class |
HadoopUtils
Utility class to work with next generation of Apache Hadoop MapReduce classes.
|
Modifier and Type | Class and Description |
---|---|
class |
BlockingShuffleOutputFormat<T>
This is the inner OutputFormat used for specify the BLOCKING_PERSISTENT result partition type of
coming edge.
|
class |
CsvInputFormat<OUT>
InputFormat that reads csv files.
|
class |
PojoCsvInputFormat<OUT>
Input format that reads csv into POJOs.
|
class |
TupleCsvInputFormat<OUT>
Input format that reads csv into tuples.
|
Modifier and Type | Class and Description |
---|---|
class |
BulkIterationResultSet<T>
Resulting
DataSet of bulk iterations. |
class |
CoGroupRawOperator<I1,I2,OUT>
A
DataSet that is the result of a CoGroup transformation. |
static class |
CrossOperator.CrossProjection<I1,I2> |
static class |
CrossOperator.ProjectCrossFunction<T1,T2,R extends Tuple> |
static class |
JoinOperator.DefaultJoin.WrappingFlatJoinFunction<IN1,IN2,OUT>
Wrapper around
JoinFunction . |
class |
KeyFunctions
This class holds static utilities to append functions that extract and prune keys.
|
class |
NoOpOperator<IN>
This operator will be ignored during translation.
|
class |
OperatorTranslation
Used for translating data sets into corresponding operators.
|
static class |
ProjectOperator.Projection<T>
A projection of
DataSet . |
Modifier and Type | Method and Description |
---|---|
Map<String,DataSet<?>> |
SingleInputUdfOperator.getBroadcastSets() |
Map<String,DataSet<?>> |
UdfOperator.getBroadcastSets()
Gets the broadcast sets (name and data set) that have been added to context of the UDF.
|
Map<String,DataSet<?>> |
TwoInputUdfOperator.getBroadcastSets() |
CrossOperatorBase.CrossHint |
CrossOperator.getCrossHint() |
Partitioner<?> |
Grouping.getCustomPartitioner()
Gets the custom partitioner to be used for this grouping, or
null , if none was
defined. |
Partitioner<?> |
PartitionOperator.getCustomPartitioner()
Gets the custom partitioner from this partitioning.
|
DataSet<T> |
DataSink.getDataSet() |
OutputFormat<T> |
DataSink.getFormat() |
DataSet<T> |
Grouping.getInputDataSet()
Returns the input DataSet of a grouping operation, that is the one before the grouping.
|
InputFormat<OUT,?> |
DataSource.getInputFormat()
Gets the input format that is executed by this data source.
|
JoinOperatorBase.JoinHint |
JoinOperator.getJoinHint()
Gets the JoinHint that describes how the join is executed.
|
JoinType |
JoinOperator.getJoinType()
Gets the JoinType that describes this join operation (e.g.
|
int[] |
DeltaIterationResultSet.getKeyPositions() |
Keys<T> |
Grouping.getKeys() |
protected Keys<I1> |
CoGroupOperator.getKeys1() |
protected Keys<I2> |
CoGroupOperator.getKeys2() |
int |
DeltaIterationResultSet.getMaxIterations() |
Partitioner<?> |
JoinOperator.getPartitioner()
Gets the custom partitioner used by this join, or
null , if none is set. |
SingleInputSemanticProperties |
ReduceOperator.getSemanticProperties() |
DualInputSemanticProperties |
JoinOperator.EquiJoin.getSemanticProperties() |
SingleInputSemanticProperties |
GroupCombineOperator.getSemanticProperties() |
SingleInputSemanticProperties |
SingleInputUdfOperator.getSemanticProperties() |
SingleInputSemanticProperties |
GroupReduceOperator.getSemanticProperties() |
SemanticProperties |
UdfOperator.getSemanticProperties()
Gets the semantic properties that have been set for the user-defined functions (UDF).
|
DualInputSemanticProperties |
TwoInputUdfOperator.getSemanticProperties() |
TypeInformation<T> |
DataSink.getType() |
boolean |
GroupReduceOperator.isCombinable() |
void |
TwoInputUdfOperator.setSemanticProperties(DualInputSemanticProperties properties)
Sets the semantic properties for the user-defined function (UDF).
|
void |
SingleInputUdfOperator.setSemanticProperties(SingleInputSemanticProperties properties)
Sets the semantic properties for the user-defined function (UDF).
|
protected CoGroupOperatorBase<?,?,OUT,?> |
CoGroupOperator.translateToDataFlow(Operator<I1> input1,
Operator<I2> input2) |
protected GroupReduceOperatorBase<IN,IN,GroupReduceFunction<IN,IN>> |
AggregateOperator.translateToDataFlow(Operator<IN> input) |
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.
|
class |
PlanBothUnwrappingCoGroupOperator<I1,I2,OUT,K>
A co group operator that applies the operation only on the unwrapped values.
|
class |
PlanFilterOperator<T> |
class |
PlanLeftUnwrappingCoGroupOperator<I1,I2,OUT,K>
A co group operator that applies the operation only on the unwrapped values on the left.
|
class |
PlanProjectOperator<T,R extends Tuple>
A map operator that retains a subset of fields from incoming tuples.
|
class |
PlanRightUnwrappingCoGroupOperator<I1,I2,OUT,K>
A co group operator that applies the operation only on the unwrapped values on the right.
|
class |
PlanUnwrappingGroupCombineOperator<IN,OUT,K>
A group combine operator that takes 2-tuples (key-value pairs), and applies the group combine
operation only on the unwrapped values.
|
class |
PlanUnwrappingReduceGroupOperator<IN,OUT,K>
A reduce operator that takes 2-tuples (key-value pairs), and applies the group reduce operation
only on the unwrapped values.
|
class |
PlanUnwrappingReduceOperator<T,K>
A reduce operator that takes 2-tuples (key-value pairs), and applies the reduce operation only on
the unwrapped values.
|
class |
PlanUnwrappingSortedGroupCombineOperator<IN,OUT,K1,K2>
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted partial
group reduce operation only on the unwrapped values.
|
class |
PlanUnwrappingSortedReduceGroupOperator<IN,OUT,K1,K2>
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted group
reduce operation only on the unwrapped values.
|
class |
Tuple3UnwrappingIterator<T,K1,K2>
An iterator that reads 3-tuples (groupKey, sortKey, value) and returns only the values (third
field).
|
class |
Tuple3WrappingCollector<IN,K1,K2>
Needed to wrap tuples to
Tuple3<groupKey, sortKey, value> for combine method of group
reduce with key selector sorting. |
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 |
TupleUnwrappingIterator<T,K>
An iterator that reads 2-tuples (key value pairs) and returns only the values (second field).
|
class |
TupleUnwrappingJoiner<I1,I2,OUT,K>
Joiner that unwraps both values before applying the join operation.
|
class |
TupleWrappingCollector<IN,K>
Needed to wrap tuples to
Tuple2<key, value> pairs for combine method of group reduce with
key selector function. |
class |
TwoKeyExtractingMapper<T,K1,K2>
Mapper that extracts two keys of a value.
|
class |
WrappingFunction<T extends Function>
Wrapper around
Function . |
Modifier and Type | Class and Description |
---|---|
class |
BernoulliSampler<T>
A sampler implementation built upon a Bernoulli trail.
|
class |
DistributedRandomSampler<T>
For sampling with fraction, the sample algorithms are natively distributed, while it's not true
for fixed size sample algorithms.
|
class |
IntermediateSampleData<T>
The data structure which is transferred between partitions and the coordinator for distributed
random sampling.
|
class |
PoissonSampler<T>
A sampler implementation based on the Poisson Distribution.
|
class |
RandomSampler<T>
A data sample is a set of data selected from a statistical population by a defined procedure.
|
class |
ReservoirSamplerWithoutReplacement<T>
A simple in memory implementation of Reservoir Sampling without replacement, and with only one
pass through the input iteration whose size is unpredictable.
|
class |
ReservoirSamplerWithReplacement<T>
A simple in memory implementation of Reservoir Sampling with replacement and with only one pass
through the input iteration whose size is unpredictable.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Aggregator<T,R>
Generic interface for aggregation.
|
class |
BooleanSummaryAggregator
Aggregator for
Boolean type. |
class |
CompensatedSum
Used to calculate sums using the Kahan summation algorithm.
|
class |
DoubleSummaryAggregator
Aggregator that can handle Double types.
|
class |
FloatSummaryAggregator
Aggregator that can handle Float types.
|
class |
IntegerSummaryAggregator
Aggregator that can handle Integer types.
|
class |
LongSummaryAggregator
Aggregator that can handle Long types.
|
class |
NumericSummaryAggregator<T extends Number>
Generic aggregator for all numeric types creates a summary of a column of numbers.
|
class |
ObjectSummaryAggregator
Aggregator that calculates statistics for Object values. |
class |
ShortSummaryAggregator
Aggregator that can handle Short types.
|
class |
StringSummaryAggregator
Aggregator that calculates statistics for String values. |
class |
SummaryAggregatorFactory
Factory for creating Summary Aggregators.
|
class |
TupleSummaryAggregator<R extends Tuple>
Aggregate tuples using an array of aggregators, one for each "column" or position within the
Tuple.
|
class |
ValueSummaryAggregator<VT extends Value,PT,R,A extends Aggregator<PT,R>>
This is a generic Aggregator for Value types like StringValue, DoubleValue, etc.
|
Modifier and Type | Class and Description |
---|---|
class |
PojoField
Represent a field definition for
PojoTypeInfo type of objects. |
class |
TypeExtractionException
Type extraction always contains some uncertainty due to unpredictable JVM differences between
vendors or versions.
|
class |
TypeExtractionUtils |
Modifier and Type | Method and Description |
---|---|
static <OUT> TypeInfoFactory<OUT> |
TypeExtractor.getTypeInfoFactory(Type t)
Returns the type information factory for a type using the factory registry or annotations.
|
Modifier and Type | Class and Description |
---|---|
class |
CopyableValueComparator<T extends CopyableValue<T> & Comparable<T>>
Comparator for all Value types that extend Key
|
class |
CopyableValueSerializer<T extends CopyableValue<T>> |
class |
DataInputViewStream
An input stream that draws its data from a
DataInputView . |
class |
DataOutputViewStream |
class |
EitherSerializer<L,R>
A
TypeSerializer for the Either type of the Java class. |
class |
EitherSerializerConfigSnapshot<L,R>
Deprecated.
|
class |
EitherSerializerSnapshot<L,R>
Deprecated.
this snapshot class is no longer used by any serializers. Instead,
JavaEitherSerializerSnapshot is used. |
class |
FieldSerializer
This class is for the serialization of java.lang.reflect.Field, which doesn't implement
Serializable, therefore readObject/writeObject need to be implemented in classes where there is a
field of type java.lang.reflect.Field.
|
class |
GenericTypeComparator<T extends Comparable<T>>
TypeComparator for all types that extend Comparable.
|
class |
KryoRegistration
A
KryoRegistration resembles a registered class and its serializer in Kryo. |
class |
KryoRegistrationSerializerConfigSnapshot<T>
Configuration snapshot base class for serializers that use Kryo for serialization.
|
class |
KryoUtils
Convenience methods for Kryo
|
class |
MaskUtils
Utilities for reading and writing binary masks.
|
class |
NoFetchingInput |
static class |
NullableSerializer.NullableSerializerConfigSnapshot<T>
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards
compatibility purposes. It is fully replaced by
NullableSerializer.NullableSerializerSnapshot . |
class |
NullAwareComparator<T>
Null-aware comparator that wraps a comparator which does not support null references.
|
class |
PojoComparator<T> |
class |
PojoSerializer<T> |
class |
PojoSerializerSnapshot<T>
Snapshot class for the
PojoSerializer . |
class |
RowComparator
Comparator for
Row . |
class |
RowSerializer
Serializer for
Row . |
class |
RuntimeComparatorFactory<T> |
class |
RuntimePairComparatorFactory<T1,T2> |
class |
RuntimeSerializerFactory<T> |
class |
Tuple0Serializer |
class |
TupleComparator<T extends Tuple> |
class |
TupleComparatorBase<T> |
class |
TupleSerializer<T extends Tuple> |
class |
TupleSerializerBase<T> |
class |
TupleSerializerConfigSnapshot<T>
Snapshot of a tuple serializer's configuration.
|
class |
TupleSerializerSnapshot<T extends Tuple>
Snapshot of a tuple serializer's configuration.
|
class |
ValueComparator<T extends Value & Comparable<T>>
Comparator for all Value types that extend Key
|
class |
ValueSerializer<T extends Value>
Serializer for
Value types. |
class |
WritableSerializer<T extends org.apache.hadoop.io.Writable>
A
TypeSerializer for Writable . |
Modifier and Type | Class and Description |
---|---|
class |
Serializers
Class containing utilities for the serializers of the Flink Runtime.
|
Modifier and Type | Class and Description |
---|---|
class |
PlanGenerator
|
Modifier and Type | Class and Description |
---|---|
class |
ScalaCaseClassSerializerSnapshot<T extends scala.Product>
TypeSerializerSnapshot for ScalaCaseClassSerializer . |
class |
Tuple2CaseClassSerializerSnapshot<T1,T2>
TypeSerializerSnapshot for ScalaCaseClassSerializer . |
Modifier and Type | Class and Description |
---|---|
static class |
PatternStream.CoMapTimeout<R,L>
Used for joining results from timeout side-output for API backward compatibility.
|
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 |
LockableTypeSerializerSnapshot<E>
|
Modifier and Type | Class and Description |
---|---|
class |
CepOperator<IN,KEY,OUT>
CEP pattern operator for a keyed input stream.
|
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 |
BooleanConditions
Utility class containing an
IterativeCondition that always returns true and one
that always returns false . |
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 |
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 |
TimerService
Enables to provide time characteristic to
NFA for use in IterativeCondition . |
Modifier and Type | Interface and Description |
---|---|
interface |
ApplicationDeployer
An interface to be used by the
CliFrontend to submit user programs for execution. |
class |
ExecutionConfigAccessor
Accessor that exposes config settings that are relevant for execution from an underlying
Configuration . |
class |
GenericCLI
A generic implementation of the
CustomCommandLine that only expects the execution.target
parameter to be explicitly specified and simply forwards the rest of the options specified with
-D to the corresponding PipelineExecutor for further parsing. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractContainerizedClusterClientFactory<ClusterID>
An abstract
ClusterClientFactory containing some common implementations for different
containerized deployment clusters. |
interface |
ClusterClientFactory<ClusterID>
A factory containing all the necessary information for creating clients to Flink clusters.
|
class |
DefaultClusterClientServiceLoader
A service provider for
cluster client factories . |
class |
StandaloneClientFactory
A
ClusterClientFactory for a standalone cluster, i.e. |
Modifier and Type | Class and Description |
---|---|
class |
ApplicationConfiguration
Application-specific configurations.
|
class |
ApplicationDispatcherBootstrap
A
DispatcherBootstrap used for running the user's main() in "Application Mode"
(see FLIP-85). |
class |
ApplicationDispatcherGatewayServiceFactory
A
DispatcherGatewayServiceFactory used when executing a job in Application Mode, i.e. |
class |
ApplicationDispatcherLeaderProcessFactoryFactory
Factory for a
DispatcherLeaderProcessFactoryFactory designed to be used when executing an
application in Application Mode. |
interface |
ApplicationRunner
An interface to be implemented by the entities responsible for application submission for the
different deployment environments.
|
class |
ClassPathPackagedProgramRetriever
A
PackagedProgramRetriever which
creates the PackagedProgram containing
the user's main() from a class on the class path. |
class |
DetachedApplicationRunner
An
ApplicationRunner which runs the user specified application using the EmbeddedExecutor . |
class |
EmbeddedJobClient
A
JobClient with the ability to also submit jobs which uses directly the DispatcherGateway . |
class |
UnsuccessfulExecutionException
Exception that signals the failure of an application with a given
ApplicationStatus . |
Modifier and Type | Class and Description |
---|---|
class |
ApplicationClusterDeployer
An entity responsible for submitting an application for execution in "Application Mode", i.e.
|
Modifier and Type | Class and Description |
---|---|
class |
EmbeddedExecutor
A base class for
executors that invoke directly methods of the Dispatcher and do not go through the REST
API. |
class |
EmbeddedExecutorFactory
An
PipelineExecutorFactory for the EmbeddedExecutor . |
class |
EmbeddedExecutorServiceLoader
A
PipelineExecutorServiceLoader that always returns an EmbeddedExecutorFactory . |
interface |
EmbeddedJobClientCreator
An interface to be implemented by
JobClient suppliers. |
class |
WebSubmissionExecutorFactory
|
class |
WebSubmissionExecutorServiceLoader
A
PipelineExecutorServiceLoader that always returns an WebSubmissionExecutorFactory . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractJobClusterExecutor<ClusterID,ClientFactory extends ClusterClientFactory<ClusterID>>
An abstract
PipelineExecutor used to execute pipelines on dedicated
(per-job) clusters. |
class |
AbstractSessionClusterExecutor<ClusterID,ClientFactory extends ClusterClientFactory<ClusterID>>
An abstract
PipelineExecutor used to execute pipelines on an existing
(session) cluster. |
class |
LocalExecutor
An
PipelineExecutor for executing a Pipeline locally. |
class |
LocalExecutorFactory
|
class |
RemoteExecutor
The
PipelineExecutor to be used when executing a job on an already running cluster. |
class |
RemoteExecutorFactory
|
Modifier and Type | Interface and Description |
---|---|
interface |
ClusterClientProvider<T>
Factory for
ClusterClients . |
interface |
PackagedProgramRetriever
Interface which allows to retrieve the
PackagedProgram . |
Modifier and Type | Class and Description |
---|---|
class |
ConfigUtils
General utilities for parsing values to configuration options.
|
class |
DeploymentOptionsInternal
Internal options used during deployment.
|
class |
GlobalConfiguration
Global configuration object for Flink.
|
class |
PipelineOptionsInternal
Pipeline options that are not meant to be used by the user.
|
class |
RestOptions
Configuration parameters for REST communication.
|
class |
TaskManagerOptionsInternal
TaskManager options that are not meant to be used by the user.
|
Modifier and Type | Class and Description |
---|---|
class |
FileSinkCommittable
Wrapper class for both type of committables in
FileSink . |
class |
FileSinkCommittableSerializer
Versioned serializer for
FileSinkCommittable . |
Modifier and Type | Class and Description |
---|---|
class |
FileCommitter
Committer implementation for
FileSink . |
Modifier and Type | Class and Description |
---|---|
class |
DefaultFileWriterBucketFactory<IN>
A factory returning
writer . |
class |
FileWriter<IN>
A
SinkWriter implementation for FileSink . |
interface |
FileWriterBucketFactory<IN>
A factory able to create
FileWriterBucket for the FileSink . |
class |
FileWriterBucketState
States for
FileWriterBucket . |
class |
FileWriterBucketStateSerializer
A
SimpleVersionedSerializer used to serialize the BucketState . |
Modifier and Type | Class and Description |
---|---|
class |
ContinuousEnumerationSettings
Settings describing how to do continuous file discovery and enumeration for the file source's
continuous discovery and streaming mode.
|
Modifier and Type | Class and Description |
---|---|
class |
ContinuousFileSplitEnumerator
A continuously monitoring enumerator.
|
class |
FileRecordFormatAdapter<T>
The FormatReaderAdapter turns a
FileRecordFormat into a BulkFormat . |
class |
FileRecords<T>
A collection of records for one file split.
|
class |
FileSourceReader<T,SplitT extends FileSourceSplit>
A
SourceReader that read records from FileSourceSplit . |
class |
StaticFileSplitEnumerator
A SplitEnumerator implementation for bounded / batch
FileSource input. |
class |
StreamFormatAdapter<T>
Adapter to turn a
StreamFormat into a BulkFormat . |
Modifier and Type | Class and Description |
---|---|
class |
RecyclableIterator<E>
Utility base class for iterators that accept a recycler.
|
Modifier and Type | Class and Description |
---|---|
class |
HBaseLookupOptions
Options for the HBase lookup.
|
class |
HBaseOptions
Common Options for HBase.
|
class |
HBaseWriteOptions
Options for HBase writing.
|
Modifier and Type | Interface and Description |
---|---|
interface |
HBaseMutationConverter<T>
A converter used to converts the input record into HBase
Mutation . |
class |
HBaseSinkFunction<T>
The sink function for HBase.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractHBaseDynamicTableSource
HBase table source implementation.
|
class |
AbstractHBaseTableSource
Creates a TableSource to scan an HBase table.
|
class |
HBaseLookupFunction
The HBaseLookupFunction is a standard user-defined table function, it can be used in tableAPI and
also useful for temporal table join plan in SQL.
|
class |
HBaseRowDataLookupFunction
The HBaseRowDataLookupFunction is a standard user-defined table function, it can be used in
tableAPI and also useful for temporal table join plan in SQL.
|
class |
TableInputSplit
This class implements a input splits for HBase.
|
Modifier and Type | Class and Description |
---|---|
class |
HBaseConfigurationUtil
This class helps to do serialization for hadoop Configuration and HBase-related classes.
|
class |
HBaseReadWriteHelper
A read and write helper for HBase.
|
class |
HBaseTableSchema
Helps to specify an HBase Table's schema.
|
class |
HBaseTypeUtils
A utility class to process data exchange with HBase type system.
|
Modifier and Type | Class and Description |
---|---|
class |
HBase1TableFactory
Factory for creating configured instances of
HBaseTableSource or sink. |
class |
HBaseValidator
The validator for HBase.
|
Modifier and Type | Class and Description |
---|---|
class |
HBaseDynamicTableSink
HBase table sink implementation.
|
class |
HBaseUpsertTableSink
An upsert
UpsertStreamTableSink for HBase. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractTableInputFormat<T>
Abstract
InputFormat to read data from HBase tables. |
class |
HBaseDynamicTableSource
HBase table source implementation.
|
class |
HBaseRowInputFormat
InputFormat subclass that wraps the access for HTables. |
class |
HBaseTableSource
Creates a TableSource to scan an HBase table.
|
Modifier and Type | Class and Description |
---|---|
class |
HBase2TableFactory
Factory for creating configured instances of
HBaseTableSource or sink. |
class |
HBaseValidator
The validator for HBase.
|
Modifier and Type | Class and Description |
---|---|
class |
HBaseDynamicTableSink
HBase table sink implementation.
|
class |
HBaseUpsertTableSink
An upsert
UpsertStreamTableSink for HBase. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractTableInputFormat<T>
Abstract
InputFormat to read data from HBase tables. |
class |
HBaseDynamicTableSource
HBase table source implementation.
|
class |
HBaseRowDataAsyncLookupFunction
The HBaseRowDataAsyncLookupFunction is an implemenation to lookup HBase data by rowkey in async
fashion.
|
class |
HBaseRowInputFormat
InputFormat subclass that wraps the access for HTables. |
class |
HBaseTableSource
Creates a TableSource to scan an HBase table.
|
Modifier and Type | Class and Description |
---|---|
class |
PostgresCatalog
Catalog for PostgreSQL.
|
Modifier and Type | Class and Description |
---|---|
class |
JdbcCatalogFactoryOptions
ConfigOption s for JdbcCatalog . |
Modifier and Type | Interface and Description |
---|---|
interface |
JdbcDialect
Handle the SQL dialect of jdbc driver.
|
Modifier and Type | Class and Description |
---|---|
class |
GenericJdbcSinkFunction<T>
A generic SinkFunction for JDBC.
|
class |
JdbcBatchingOutputFormat<In,JdbcIn,JdbcExec extends JdbcBatchStatementExecutor<JdbcIn>>
A JDBC outputFormat that supports batching records before writing records to database.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JdbcConnectionProvider
JDBC connection provider.
|
Modifier and Type | Class and Description |
---|---|
class |
InsertOrUpdateJdbcExecutor<R,K,V>
Deprecated.
This has been replaced with
TableInsertOrUpdateStatementExecutor , will remove
this once JdbcUpsertTableSink is removed. |
interface |
JdbcBatchStatementExecutor<T>
Executes the given JDBC statement in batch for the accumulated records.
|
class |
TableInsertOrUpdateStatementExecutor
JdbcBatchStatementExecutor that provides upsert semantics by updating row if it exists
and inserting otherwise. |
Modifier and Type | Class and Description |
---|---|
class |
JdbcDynamicTableFactory
Factory for creating configured instances of
JdbcDynamicTableSource and JdbcDynamicTableSink . |
class |
JdbcDynamicTableSink
A
DynamicTableSink for JDBC. |
class |
JdbcDynamicTableSource
A
DynamicTableSource for JDBC. |
class |
JdbcRowDataInputFormat
InputFormat for
JdbcDynamicTableSource . |
class |
JdbcRowDataLookupFunction
A lookup function for
JdbcDynamicTableSource . |
Modifier and Type | Class and Description |
---|---|
class |
JdbcTypeUtil
Utils for jdbc type.
|
Modifier and Type | Class and Description |
---|---|
class |
CheckpointAndXid
A pair of checkpoint id and
Xid representing a checkpoint and an associated pending
(prepared) XA transaction. |
class |
CheckpointAndXidSerializer
CheckpointAndXid serializer. |
class |
JdbcXaSinkFunction<T>
JDBC sink function that uses XA transactions to provide exactly once guarantees.
|
interface |
XaFacade
Facade to the XA operations relevant to
sink . |
class |
XaSinkStateSerializer
XaSinkStateSerializer.
|
interface |
XidGenerator
Xid generator. |
class |
XidSerializer
Xid serializer. |
Modifier and Type | Class and Description |
---|---|
class |
KafkaSourceEnumerator
The enumerator class for Kafka source.
|
Modifier and Type | Class and Description |
---|---|
class |
NoStoppingOffsetsInitializer
An implementation of
OffsetsInitializer which does not initialize anything. |
interface |
OffsetsInitializerValidator
Interface for validating
OffsetsInitializer with properties from KafkaSource . |
Modifier and Type | Interface and Description |
---|---|
interface |
HiveContinuousPartitionContext<P,T extends Comparable<T>>
Context for Hive continuous partition fetcher.
|
class |
HiveContinuousPartitionFetcher<T extends Comparable<T>>
A
ContinuousPartitionFetcher for hive table. |
interface |
HivePartitionContext<P>
Context for Hive partition fetcher.
|
Modifier and Type | Class and Description |
---|---|
class |
StandaloneApplicationClusterEntryPoint
An
ApplicationClusterEntryPoint which is started with a job in a predefined location. |
Modifier and Type | Class and Description |
---|---|
class |
RocksDBNativeMetricMonitor
A monitor which pulls {
RocksDB } native metrics and forwards them to Flink's metric group. |
class |
RocksDBProperty
RocksDB properties that can be queried by Flink's metrics reporter. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRocksStateKeysIterator<K>
Base class for iterators over RocksDB column families.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultExecutorServiceLoader
The default implementation of the
PipelineExecutorServiceLoader . |
class |
DetachedJobExecutionResult
The
JobExecutionResult returned by a context environment when executing a job in detached
mode. |
interface |
PipelineExecutor
The entity responsible for executing a
Pipeline , i.e. |
interface |
PipelineExecutorFactory
A factory for selecting and instantiating the adequate
PipelineExecutor based on a
provided Configuration . |
interface |
PipelineExecutorServiceLoader
An interface to be implemented by the entity responsible for finding the correct
PipelineExecutor to execute a given Pipeline . |
Modifier and Type | Class and Description |
---|---|
class |
CloseableRegistry
This class allows to register instances of
Closeable , which are all closed if this
registry is closed. |
class |
ClosingFSDataInputStream
This class is a
WrappingProxy for FSDataInputStream that is
used to implement a safety net against unclosed streams. |
class |
ClosingFSDataOutputStream
This class is a
WrappingProxy for FSDataOutputStream that
is used to implement a safety net against unclosed streams. |
class |
ConnectionLimitingFactory
A wrapping factory that adds a
LimitedConnectionsFileSystem to a file system. |
class |
FileSystemSafetyNet
The FileSystemSafetyNet can be used to guard a thread against
FileSystem stream resource
leaks. |
class |
FSDataInputStreamWrapper
Simple forwarding wrapper around
FSDataInputStream . |
class |
FSDataOutputStreamWrapper
Simple forwarding wrapper around
FSDataInputStream . |
class |
LimitedConnectionsFileSystem
A file system that limits the number of concurrently open input streams, output streams, and
total streams for a target file system.
|
class |
RefCountedFile
A reference counted file which is deleted as soon as no caller holds a reference to the wrapped
File . |
class |
SafetyNetCloseableRegistry
This implementation of an
AbstractCloseableRegistry registers WrappingProxyCloseable . |
class |
SafetyNetWrapperFileSystem
This is a
WrappingProxy around FileSystem which (i) wraps all opened streams as
ClosingFSDataInputStream or ClosingFSDataOutputStream and (ii) registers them to
a SafetyNetCloseableRegistry . |
interface |
WrappingProxyCloseable<T extends Closeable>
WrappingProxy for Closeable that is also closeable. |
Modifier and Type | Method and Description |
---|---|
static void |
FileSystemSafetyNet.closeSafetyNetAndGuardedResourcesForThread()
Closes the safety net for a thread.
|
static FileSystem |
FileSystem.getUnguardedFileSystem(URI fsUri) |
static void |
FileSystemSafetyNet.initializeSafetyNetForThread()
Activates the safety net for a thread.
|
Modifier and Type | Class and Description |
---|---|
class |
LocalBlockLocation
Implementation of the
BlockLocation interface for a local file system. |
class |
LocalDataInputStream
The
LocalDataInputStream class is a wrapper class for a data input stream to the
local file system. |
class |
LocalDataOutputStream
The
LocalDataOutputStream class is a wrapper class for a data output stream to the
local file system. |
class |
LocalFileStatus
The class
LocalFileStatus provides an implementation of the FileStatus
interface for the local file system. |
class |
LocalFileSystem
The class
LocalFileSystem is an implementation of the FileSystem interface for
the local file system of the machine where the JVM runs. |
class |
LocalRecoverableWriter
A
RecoverableWriter for the LocalFileSystem . |
Modifier and Type | Class and Description |
---|---|
class |
PostVersionedIOReadableWritable
A
VersionedIOReadableWritable which allows to differentiate whether the previous data was
versioned with a VersionedIOReadableWritable . |
interface |
SimpleVersionedSerializer<E>
A simple serializer interface for versioned serialization.
|
class |
SimpleVersionedSerializerTypeSerializerProxy<T>
A
TypeSerializer that delegates to an underlying SimpleVersionedSerializer . |
class |
VersionedIOReadableWritable
This is the abstract base class for
IOReadableWritable which allows to differentiate
between serialization versions. |
Modifier and Type | Class and Description |
---|---|
class |
ByteArrayInputStreamWithPos
Un-synchronized stream similar to Java's ByteArrayInputStream that also exposes the current
position.
|
class |
ByteArrayOutputStreamWithPos
Un-synchronized stream similar to Java's ByteArrayOutputStream that also exposes the current
position.
|
class |
ManagedMemoryUseCase
Use cases of managed memory.
|
class |
MemorySegment
This class represents a piece of memory managed by Flink.
|
class |
MemorySegmentFactory
A factory for memory segments (
MemorySegment ). |
interface |
MemorySegmentSource
Interface describing entities that can provide memory segments.
|
interface |
MemorySegmentWritable
Provides the interface for write(Segment).
|
class |
MemoryUtils
Utility class for memory operations.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultPluginManager
Default implementation of
PluginManager . |
Modifier and Type | Class and Description |
---|---|
class |
AvroToRowDataConverters
Tool class used to convert from Avro
GenericRecord to RowData . |
class |
RowDataToAvroConverters
Tool class used to convert from
RowData to Avro GenericRecord . |
Modifier and Type | Class and Description |
---|---|
class |
DebeziumAvroDeserializationSchema
Deserialization schema from Debezium Avro to Flink Table/SQL internal data structure
RowData . |
class |
DebeziumAvroSerializationSchema
Serialization schema from Flink Table/SQL internal data structure
RowData to Debezium
Avro. |
Modifier and Type | Class and Description |
---|---|
class |
AvroFactory<T>
Creates Avro
DatumReader and DatumWriter . |
Modifier and Type | Class and Description |
---|---|
class |
TimeFormats
Time formats and timestamp formats respecting the RFC3339 specification, ISO-8601 specification
and SQL specification.
|
class |
TimestampFormat
Timestamp format Enums.
|
Modifier and Type | Class and Description |
---|---|
class |
CsvRowDataDeserializationSchema
Deserialization schema from CSV to Flink Table & SQL internal data structures.
|
static class |
CsvRowDataDeserializationSchema.Builder
A builder for creating a
CsvRowDataDeserializationSchema . |
class |
CsvToRowDataConverters
Tool class used to convert from CSV-format
JsonNode to RowData . |
class |
RowDataToCsvConverters
Tool class used to convert from
RowData to CSV-format JsonNode . |
Modifier and Type | Interface and Description |
---|---|
interface |
HadoopFileCommitter
The committer publishes an intermediate Hadoop file to the target path after it finishes writing.
|
interface |
HadoopFileCommitterFactory
The factory to create the
HadoopFileCommitter . |
interface |
HadoopPathBasedBulkWriter<T>
Specialized
BulkWriter which is expected to write to specified Path . |
Modifier and Type | Class and Description |
---|---|
class |
JsonRowDataDeserializationSchema
Deserialization schema from JSON to Flink Table/SQL internal data structure
RowData . |
class |
JsonRowDataSerializationSchema
Serialization schema that serializes an object of Flink internal data structure into a JSON
bytes.
|
class |
JsonToRowDataConverters
Tool class used to convert from
JsonNode to RowData . |
class |
RowDataToJsonConverters
Tool class used to convert from
RowData to JsonNode . |
Modifier and Type | Class and Description |
---|---|
static class |
CanalJsonDeserializationSchema.Builder
A builder for creating a
CanalJsonDeserializationSchema . |
Modifier and Type | Class and Description |
---|---|
class |
DebeziumJsonDeserializationSchema
Deserialization schema from Debezium JSON to Flink Table/SQL internal data structure
RowData . |
Modifier and Type | Class and Description |
---|---|
class |
BackPressuringExecutor
An executor decorator that allows only a certain number of concurrent executions.
|
class |
OffsetAwareOutputStream
An
OutputStream that keeps track of its current length. |
class |
RefCountedBufferingFileStream
A
RefCountedFileWithStream that also uses an in-memory buffer for buffering small writes. |
class |
RefCountedFileWithStream
A reference counted file which is deleted as soon as no caller holds a reference to the wrapped
File . |
class |
RefCountedFSOutputStream
A
FSDataOutputStream with the RefCounted functionality. |
class |
RefCountedTmpFileCreator
A utility class that creates local
reference counted files that
serve as temporary files. |
Modifier and Type | Interface and Description |
---|---|
interface |
S3AccessHelper
An interface that abstracts away the Multi-Part Upload (MPU) functionality offered by S3, from
the specific implementation of the file system.
|
Modifier and Type | Class and Description |
---|---|
class |
ByteValueArrayComparator
Specialized comparator for ByteValueArray based on CopyableValueComparator.
|
class |
CharValueArrayComparator
Specialized comparator for CharValueArray based on CopyableValueComparator.
|
class |
DoubleValueArrayComparator
Specialized comparator for DoubleValueArray based on CopyableValueComparator.
|
class |
FloatValueArrayComparator
Specialized comparator for FloatValueArray based on CopyableValueComparator.
|
class |
IntValueArrayComparator
Specialized comparator for IntValueArray based on CopyableValueComparator.
|
class |
LongValueArrayComparator
Specialized comparator for LongValueArray based on CopyableValueComparator.
|
class |
NullValueArrayComparator
Specialized comparator for NullValueArray based on CopyableValueComparator.
|
class |
ShortValueArrayComparator
Specialized comparator for ShortValueArray based on CopyableValueComparator.
|
class |
StringValueArrayComparator
Specialized comparator for StringValueArray based on CopyableValueComparator.
|
Modifier and Type | Class and Description |
---|---|
class |
KubernetesClusterClientFactory
A
ClusterClientFactory for a Kubernetes cluster. |
Modifier and Type | Class and Description |
---|---|
class |
KubernetesSessionCli
Kubernetes customized commandline.
|
Modifier and Type | Class and Description |
---|---|
class |
KubernetesConfigOptionsInternal
Kubernetes configuration options that are not meant to be set by the user.
|
class |
KubernetesDeploymentTarget
A class containing all the supported deployment target names for Kubernetes.
|
Modifier and Type | Class and Description |
---|---|
class |
KubernetesApplicationClusterEntrypoint
An
ApplicationClusterEntryPoint for Kubernetes. |
Modifier and Type | Class and Description |
---|---|
class |
KubernetesSessionClusterExecutor
The
PipelineExecutor to be used when executing a job on an already running cluster. |
class |
KubernetesSessionClusterExecutorFactory
An
PipelineExecutorFactory for executing jobs on an existing (session) cluster. |
Modifier and Type | Class and Description |
---|---|
class |
OrcBulkWriter<T>
A
BulkWriter implementation that writes data in ORC format. |
class |
PhysicalWriterImpl
A slightly customised clone of
PhysicalFsWriter . |
class |
ThreadLocalClassLoaderConfiguration
Workaround for https://issues.apache.org/jira/browse/ORC-653.
|
Modifier and Type | Class and Description |
---|---|
class |
PythonConfig
Configurations for the Python job which are used at run time.
|
interface |
PythonFunctionRunner
The base interface of runner which is responsible for the execution of Python functions.
|
Modifier and Type | Class and Description |
---|---|
class |
ProcessPythonEnvironment
A
PythonEnvironment for executing UDFs in Process. |
class |
PythonDependencyInfo
PythonDependencyInfo contains the information of third-party dependencies.
|
interface |
PythonEnvironment
The base interface of python environment for executing UDFs.
|
interface |
PythonEnvironmentManager
The base interface of python environment manager which is used to create the PythonEnvironment
object and the RetrievalToken.
|
Modifier and Type | Class and Description |
---|---|
class |
ProcessPythonEnvironmentManager
The ProcessPythonEnvironmentManager is used to prepare the working dir of python UDF worker and
create ProcessPythonEnvironment object of Beam Fn API.
|
Modifier and Type | Class and Description |
---|---|
class |
FlinkMetricContainer
Helper class for forwarding Python metrics to Java accumulators and metrics.
|
Modifier and Type | Class and Description |
---|---|
class |
PythonDependencyUtils
Utility class for Python dependency management.
|
class |
PythonEnvironmentManagerUtils
Utils used to prepare the python environment.
|
class |
ZipUtils
Utils used to extract zip files and try to restore the origin permissions of files.
|
Modifier and Type | Class and Description |
---|---|
class |
VoidNamespace
Singleton placeholder class for state without a namespace.
|
class |
VoidNamespaceSerializer
Serializer for
VoidNamespace . |
class |
VoidNamespaceTypeInfo
|
Modifier and Type | Class and Description |
---|---|
class |
KvStateClientProxyHandler
This handler acts as an internal (to the Flink cluster) client that receives the requests from
external clients, executes them by contacting the Job Manager (if necessary) and the Task Manager
holding the requested state, and forwards the answer back to the client.
|
class |
KvStateClientProxyImpl
The default implementation of the
KvStateClientProxy . |
Modifier and Type | Class and Description |
---|---|
class |
UnknownKeyOrNamespaceException
Thrown if the KvState does not hold any state for the given key or namespace.
|
class |
UnknownKvStateIdException
Thrown if no KvState with the given ID cannot found by the server handler.
|
class |
UnknownKvStateKeyGroupLocationException
Exception thrown if there is no location information available for the given key group.
|
class |
UnknownLocationException
Exception to fail Future if the Task Manager on which the
Client Proxy is running on,
does not know the location of a requested state. |
Modifier and Type | Class and Description |
---|---|
class |
KvStateInternalRequest
The request to be forwarded by the
Queryable State Client Proxy to the State
Server of the Task Manager responsible for the requested state. |
class |
KvStateRequest
The request to be sent by the
Queryable State Client to the Client Proxy requesting a given state. |
class |
KvStateResponse
The response containing the (serialized) state sent by the
State Server to the Client Proxy , and then forwarded by the proxy to the original Queryable State Client . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractServerBase<REQ extends MessageBody,RESP extends MessageBody>
The base class for every server in the queryable state module.
|
class |
AbstractServerHandler<REQ extends MessageBody,RESP extends MessageBody>
The base class of every handler used by an
AbstractServerBase . |
class |
BadRequestException
Base class for exceptions thrown during querying Flink's managed state.
|
class |
ChunkedByteBuf
A
ByteBuf instance to be consumed in chunks by ChunkedWriteHandler , respecting
the high and low watermarks. |
class |
Client<REQ extends MessageBody,RESP extends MessageBody>
The base class for every client in the queryable state module.
|
class |
ClientHandler<REQ extends MessageBody,RESP extends MessageBody>
The handler used by a
Client to handling incoming messages. |
interface |
ClientHandlerCallback<RESP extends MessageBody>
Callback for
ClientHandler . |
Modifier and Type | Class and Description |
---|---|
class |
MessageBody
|
interface |
MessageDeserializer<M extends MessageBody>
A utility used to deserialize a
message . |
class |
MessageSerializer<REQ extends MessageBody,RESP extends MessageBody>
|
class |
MessageType
|
class |
RequestFailure
A message indicating a protocol-related error.
|
Modifier and Type | Class and Description |
---|---|
class |
KvStateServerHandler
This handler dispatches asynchronous tasks, which query
InternalKvState instances and
write the result to the channel. |
class |
KvStateServerImpl
The default implementation of the
KvStateServer . |
Modifier and Type | Class and Description |
---|---|
class |
CheckpointRetentionPolicy
Policy for whether checkpoints are retained after a job terminates.
|
interface |
OperatorStateRepartitioner<T>
Interface that allows to implement different strategies for repartitioning of operator state as
parallelism changes.
|
class |
PrioritizedOperatorSubtaskState
This class is a wrapper over multiple alternative
OperatorSubtaskState that are (partial)
substitutes for each other and imposes a priority ordering over all alternatives for the
different states which define an order in which the operator should attempt to restore the state
from them. |
static class |
PrioritizedOperatorSubtaskState.Builder
A builder for PrioritizedOperatorSubtaskState.
|
class |
RoundRobinOperatorStateRepartitioner
Current default implementation of
OperatorStateRepartitioner that redistributes state in
round robin fashion. |
class |
StateAssignmentOperation
This class encapsulates the operation of assigning restored state when restoring from a
checkpoint.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ChannelStateWriter
Writes channel state during checkpoint/savepoint.
|
class |
ChannelStateWriterImpl
ChannelStateWriter implemented using CheckpointStateOutputStreams . |
class |
InputChannelInfo
Identifies
InputChannel in a given
subtask. |
class |
ResultSubpartitionInfo
Identifies
ResultSubpartition in a given subtask. |
interface |
SequentialChannelStateReader
Reads channel state saved during checkpoint/savepoint.
|
Modifier and Type | Class and Description |
---|---|
class |
MetadataV1Serializer
Deserializer for checkpoints written in format
1 (Flink 1.2.x format). |
class |
MetadataV2Serializer
(De)serializer for checkpoint metadata format version 2.
|
class |
MetadataV2V3SerializerBase
Base (De)serializer for checkpoint metadata format version 2 and 3.
|
class |
MetadataV3Serializer
(De)serializer for checkpoint metadata format version 3.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DispatcherBootstrap
An interface containing the logic of bootstrapping the
Dispatcher of a cluster. |
interface |
DispatcherBootstrapFactory
A factory to create a
DispatcherBootstrap . |
class |
NoOpDispatcherBootstrap
A
DispatcherBootstrap which submits the provided job graphs for
execution upon dispatcher initialization. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDispatcherLeaderProcess
A base
DispatcherLeaderProcess . |
class |
DefaultDispatcherGatewayService
A facade over the
Dispatcher that exposes specific functionality. |
interface |
DispatcherLeaderProcessFactoryFactory
Factory for
DispatcherLeaderProcessFactory . |
class |
SessionDispatcherLeaderProcessFactory
Factory for the
SessionDispatcherLeaderProcess . |
Modifier and Type | Class and Description |
---|---|
class |
HadoopRecoverableWriter
An implementation of the
RecoverableWriter for Hadoop's file system abstraction. |
Modifier and Type | Interface and Description |
---|---|
interface |
AvailabilityProvider
Interface defining couple of essential methods for listening on data availability using
CompletableFuture . |
interface |
PullingAsyncDataInput<T>
Interface defining couple of essential methods for asynchronous and non blocking data polling.
|
Modifier and Type | Class and Description |
---|---|
class |
FileBasedBufferIterator
CloseableIterator of buffers over file content. |
Modifier and Type | Class and Description |
---|---|
class |
SubtaskStateMapper
The
SubtaskStateMapper narrows down the subtasks that need to be read during rescaling to
recover from a particular subtask when in-flight data has been stored in the checkpoint. |
Modifier and Type | Class and Description |
---|---|
class |
PrioritizedDeque<T>
A deque-like data structure that supports prioritization of elements, such they will be polled
before any non-priority elements.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CheckpointableInput
Input, with just basic methods for blocking and resuming consumption.
|
Modifier and Type | Class and Description |
---|---|
static class |
JobResult.Builder
Builder for
JobResult . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMetricGroup<A extends AbstractMetricGroup<?>>
Abstract
MetricGroup that contains key functionality for adding metrics and groups. |
class |
ComponentMetricGroup<P extends AbstractMetricGroup<?>>
Abstract
MetricGroup for system components (e.g., TaskManager,
Job, Task, Operator). |
class |
GenericKeyMetricGroup
A
GenericMetricGroup for representing the key part of a key-value metric group pair. |
class |
GenericMetricGroup
A simple named
MetricGroup that is used to hold subgroups of
metrics. |
class |
GenericValueMetricGroup
A
GenericMetricGroup for representing the value part of a key-value metric group pair. |
class |
JobManagerJobMetricGroup
Special
MetricGroup representing everything belonging to a
specific job, running on the JobManager. |
class |
JobMetricGroup<C extends ComponentMetricGroup<C>>
Special abstract
MetricGroup representing everything belonging
to a specific job. |
class |
OperatorMetricGroup
Special
MetricGroup representing an Operator. |
class |
TaskManagerJobMetricGroup
Special
MetricGroup representing everything belonging to a
specific job, running on the TaskManager. |
class |
TaskManagerMetricGroup
Special
MetricGroup representing a TaskManager. |
class |
TaskMetricGroup
Special
MetricGroup representing a Flink runtime Task. |
Modifier and Type | Class and Description |
---|---|
class |
KvStateEntry<K,N,V>
An entry holding the
InternalKvState along with its KvStateInfo . |
Modifier and Type | Interface and Description |
---|---|
interface |
ScaleUpController
Simple policy for controlling the scale up behavior of the
AdaptiveScheduler . |
Modifier and Type | Class and Description |
---|---|
class |
KerberosUtils
Provides vendor-specific Kerberos
AppConfigurationEntry instances. |
Modifier and Type | Class and Description |
---|---|
class |
JaasModule
Responsible for installing a process-wide JAAS configuration.
|
Modifier and Type | Class and Description |
---|---|
class |
SourceCoordinator<SplitT extends SourceSplit,EnumChkT>
The default implementation of the
OperatorCoordinator for the Source . |
class |
SourceCoordinatorContext<SplitT extends SourceSplit>
A context class for the
OperatorCoordinator . |
class |
SplitAssignmentTracker<SplitT extends SourceSplit>
A class that is responsible for tracking the past split assignments made by
SplitEnumerator . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractChannelStateHandle<Info>
Abstract channel state handle.
|
class |
CheckpointStorageLoader
This class contains utility methods to load checkpoint storage from configurations.
|
interface |
ConfigurableCheckpointStorage
An interface for checkpoint storage types that pick up additional parameters from a
configuration.
|
interface |
ConfigurableStateBackend
An interface for state backends that pick up additional parameters from a configuration.
|
class |
DefaultOperatorStateBackend
Default implementation of OperatorStateStore that provides the ability to make snapshots.
|
interface |
FullSnapshotResources<K>
A
SnapshotResources to be used with the backend-independent FullSnapshotAsyncWriter . |
class |
HeapPriorityQueuesManager
Manages creating heap priority queues along with their counterpart meta info.
|
class |
InputChannelStateHandle
Handle to an InputChannel state. |
interface |
InternalPriorityQueue<T>
Interface for collection that gives in order access to elements w.r.t their priority.
|
interface |
IterableStateSnapshot<K,N,S>
A
StateSnapshot that can return an iterator over all contained StateEntries . |
class |
JavaSerializer<T extends Serializable>
A
TypeSerializer that uses Java serialization. |
interface |
OwnedTaskLocalStateStore
This interface represents the administrative interface to
TaskLocalStateStore , that only
the owner of the object should see. |
class |
ResultSubpartitionStateHandle
Handle to a ResultSubpartition state. |
class |
SavepointResources<K>
Savepoint resources for a
KeyedStateBackend . |
class |
SerializedCompositeKeyBuilder<K>
Responsible for serialization of currentKey, currentGroup and namespace.
|
class |
SnappyStreamCompressionDecorator
This implementation decorates the stream with snappy compression.
|
interface |
Snapshotable<S extends StateObject>
Interface for objects that can snapshot its state (state backends currently).
|
interface |
SnapshotResources
A set of resources produced in the synchronous part of a snapshot required to finish the
snapshot.
|
interface |
SnapshotStrategy<S extends StateObject,SR extends SnapshotResources>
Interface for different snapshot approaches in state backends.
|
class |
StateSerializerProvider<T>
A
StateSerializerProvider wraps logic on how to obtain serializers for registered state,
either with the previous schema of state in checkpoints or the current schema of state. |
interface |
StateSnapshot
General interface for state snapshots that should be written partitioned by key-groups.
|
interface |
StateSnapshotKeyGroupReader
Interface for state de-serialization into
StateTable s by key-group. |
interface |
StateSnapshotRestore
Interface to deal with state snapshot and restore of state.
|
interface |
StateTransformationFunction<S,T>
Interface for a binary function that is used for push-down of state transformation into state
backends.
|
class |
StreamCompressionDecorator
Implementations of this interface decorate streams with a compression scheme.
|
interface |
TaskLocalStateStore
Classes that implement this interface serve as a task-manager-level local storage for local
checkpointed state.
|
class |
UncompressedStreamCompressionDecorator
This implementation does not decorate the stream with any compression.
|
Modifier and Type | Interface and Description |
---|---|
interface |
SequenceNumber
A logical timestamp to draw a boundary between the materialized and non-materialized changes.
|
class |
StateChange
Change of state of a keyed operator.
|
interface |
StateChangelogHandle<ReaderContext>
A handle to saved
state changes . |
class |
StateChangelogHandleStreamImpl
StateChangelogHandle implementation based on StreamStateHandle . |
interface |
StateChangelogWriter<Handle extends StateChangelogHandle<?>>
Allows to write data to the log.
|
interface |
StateChangelogWriterFactory<Handle extends StateChangelogHandle<?>>
StateChangelogWriter factory. |
class |
StateChangelogWriterFactoryLoader
A thin wrapper around
PluginManager to load StateChangelogWriterFactory . |
Modifier and Type | Interface and Description |
---|---|
interface |
DelegatingStateBackend
An interface to delegate state backend.
|
Modifier and Type | Method and Description |
---|---|
static FsCompletedCheckpointStorageLocation |
AbstractFsCheckpointStorageAccess.resolveCheckpointPointer(String checkpointPointer)
Takes the given string (representing a pointer to a checkpoint) and resolves it to a file
status for the checkpoint's metadata file.
|
Modifier and Type | Class and Description |
---|---|
class |
CopyOnWriteStateTableSnapshot<K,N,S>
This class represents the snapshot of a
CopyOnWriteStateTable and has a role in operator
state checkpointing. |
class |
HeapKeyValueStateIterator
A
KeyValueStateIterator over Heap backend snapshot
resources. |
interface |
HeapPriorityQueueElement
Interface for objects that can be managed by a
HeapPriorityQueue . |
interface |
InternalKeyContext<K>
This interface is the current context of a keyed state.
|
class |
NestedMapsStateTable<K,N,S>
This implementation of
StateTable uses NestedStateMap . |
class |
StateTableByKeyGroupReaders
This class provides a static factory method to create different implementations of
StateSnapshotKeyGroupReader depending on the provided serialization format version. |
Modifier and Type | Class and Description |
---|---|
class |
LatencyTrackingStateConfig
Config to create latency tracking state metric.
|
Modifier and Type | Class and Description |
---|---|
class |
FullSnapshotRestoreOperation<K>
The procedure of restoring state from a savepoint written with the unified binary format.
|
class |
KeyGroup
Part of a savepoint representing data for a single key group.
|
class |
KeyGroupEntry
Part of a savepoint representing data for a single state entry in a key group.
|
interface |
ThrowingIterator<E>
Modified
Iterator interface that lets the implementation throw an IOException . |
Modifier and Type | Interface and Description |
---|---|
interface |
CheckpointResponder
Responder for checkpoint acknowledge and decline messages in the
Task . |
Modifier and Type | Class and Description |
---|---|
class |
ForwardingInputStream
Input stream, that wraps another input stream and forwards all method calls to the wrapped
stream.
|
class |
ForwardingOutputStream
Output stream, that wraps another input stream and forwards all method calls to the wrapped
stream.
|
class |
NonClosingInputStreamDecorator
Decorator for input streams that ignores calls to
InputStream.close() . |
class |
NonClosingOutpusStreamDecorator
Decorator for input streams that ignores calls to
OutputStream.close() . |
Modifier and Type | Class and Description |
---|---|
class |
SqlReset
SQL call for "RESET" and "RESET 'key'".
|
class |
SqlSet
SQL call for "SET" and "SET 'key' = 'value'".
|
Modifier and Type | Class and Description |
---|---|
class |
SqlRawTypeNameSpec
Represents a raw type such as
RAW('org.my.Class', 'sW3Djsds...') . |
class |
SqlTimestampLtzTypeNameSpec
Represents type TIMESTAMP_LTZ(int) which is a synonym of type TIMESTAMP(int) WITH LOCAL TIME
ZONE.
|
Modifier and Type | Method and Description |
---|---|
<R> BootstrapTransformation<T> |
WindowedOperatorTransformation.reduce(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
Modifier and Type | Class and Description |
---|---|
class |
BroadcastStateInputFormat<K,V>
The input format for reading
BroadcastState . |
class |
KeyedStateInputFormat<K,N,OUT>
Input format for reading partitioned state.
|
class |
ListStateInputFormat<OT>
Input format for reading operator list state.
|
class |
MultiStateKeyIterator<K>
An iterator for reading all keys in a state backend across multiple partitioned states.
|
class |
UnionStateInputFormat<OT>
Input format for reading operator union state.
|
Modifier and Type | Class and Description |
---|---|
class |
KeyedStateReaderOperator<KEY,OUT>
A
StateReaderOperator for executing a KeyedStateReaderFunction . |
class |
StateReaderOperator<F extends Function,KEY,N,OUT>
Base class for executing functions that read keyed state.
|
class |
WindowReaderOperator<S extends State,KEY,IN,W extends Window,OUT>
A
StateReaderOperator for reading WindowOperator state. |
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 |
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 |
KeyGroupRangeInputSplit
An input split representing a key-group range from a savepoint.
|
class |
OperatorStateInputSplit
An input split containing state handles for operator state.
|
Modifier and Type | Class and Description |
---|---|
class |
BoundedOneInputStreamTaskRunner<IN>
A
RichMapPartitionFunction that serves as the runtime for a BoundedStreamTask . |
class |
FileCopyFunction
This output format copies files from an existing savepoint into a new directory.
|
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 |
SavepointOutputFormat
An output format to serialize
CheckpointMetadata metadata to distributed storage. |
class |
SnapshotUtils
Takes a final snapshot of the state of an operator subtask.
|
class |
StatePathExtractor
Extracts all file paths that are part of the provided
OperatorState . |
class |
TaggedOperatorSubtaskState
A simple wrapper pojo that tags
OperatorSubtaskState with metadata. |
class |
TimestampAssignerWrapper<T>
Wraps an existing
TimestampAssigner into a Timestamper . |
Modifier and Type | Class and Description |
---|---|
class |
BroadcastStateBootstrapOperator<IN>
A
StreamOperator for executing BroadcastStateBootstrapFunction 's. |
class |
KeyedStateBootstrapOperator<K,IN>
A
StreamOperator for executing KeyedStateBootstrapFunction 's. |
class |
LazyTimerService
A timer service that initializes its internal timer service lazily.
|
class |
StateBootstrapOperator<IN>
A
StreamOperator for executing StateBootstrapFunction 's. |
class |
StateBootstrapWrapperOperator<IN,OUT,OP extends AbstractStreamOperator<OUT> & OneInputStreamOperator<IN,OUT>>
Wraps an existing operator so it can be bootstrapped.
|
Modifier and Type | Class and Description |
---|---|
class |
HashSelector<IN>
A wrapper around a
KeySelector that returns the Object.hashCode() of the returned
key. |
class |
KeyGroupRangePartitioner
A partitioner that selects the target channel based on the key group index.
|
Modifier and Type | Class and Description |
---|---|
class |
BootstrapTransformationWithID<T>
A simple container class that represents a newly bootstrapped operator state within savepoints.
|
class |
NeverFireProcessingTimeService
A processing time service whose timers never fire so all timers are included in savepoints.
|
class |
OperatorIDGenerator
Utility for generating Operator Id's from uid strings.
|
class |
SavepointEnvironment
A minimally implemented
Environment that provides the functionality required to run the
state-processor-api . |
class |
SavepointLoader
Utility class for loading
CheckpointMetadata metadata. |
class |
SavepointRuntimeContext
A streaming
RuntimeContext which delegates to the underlying batch RuntimeContext
along with a specified KeyedStateStore . |
class |
VoidTriggerable<K,N>
A
Triggerable that does nothing. |
Modifier and Type | Class and Description |
---|---|
class |
SavepointMetadata
Savepoint metadata that can be modified.
|
Modifier and Type | Class and Description |
---|---|
class |
SimpleTimerService
Implementation of
TimerService that uses a InternalTimerService . |
Modifier and Type | Class and Description |
---|---|
static class |
CoGroupedStreams.TaggedUnion<T1,T2>
Internal class for implementing tagged union co-group.
|
static class |
CoGroupedStreams.UnionSerializer<T1,T2>
|
Modifier and Type | Method and Description |
---|---|
int |
DataStream.getId()
Returns the ID of the
DataStream in the current StreamExecutionEnvironment . |
KeySelector<T,KEY> |
KeyedStream.getKeySelector()
Gets the key selector that can get the key by which the stream if partitioned from the
elements.
|
TypeInformation<KEY> |
KeyedStream.getKeyType()
Gets the type of the key by which the stream is partitioned.
|
Transformation<T> |
DataStream.getTransformation()
Returns the
Transformation that represents the operation that logically creates this
DataStream . |
LegacySinkTransformation<T> |
DataStreamSink.getTransformation()
Returns the transformation that contains the actual sink operator of this sink.
|
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.process(CoProcessFunction<IN1,IN2,R> coProcessFunction,
TypeInformation<R> outputType)
Applies the given
CoProcessFunction on the connected input streams, thereby creating
a transformed output stream. |
<K,R> SingleOutputStreamOperator<R> |
ConnectedStreams.process(KeyedCoProcessFunction<K,IN1,IN2,R> keyedCoProcessFunction,
TypeInformation<R> outputType)
Applies the given
KeyedCoProcessFunction on the connected input streams, thereby
creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(KeyedProcessFunction<KEY,T,R> keyedProcessFunction,
TypeInformation<R> outputType)
Applies the given
KeyedProcessFunction on the input stream, thereby creating a
transformed output stream. |
<R> SingleOutputStreamOperator<R> |
DataStream.process(ProcessFunction<T,R> processFunction,
TypeInformation<R> outputType)
Applies the given
ProcessFunction on the input stream, thereby creating a transformed
output stream. |
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(ProcessFunction<T,R> processFunction,
TypeInformation<R> outputType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.process(ProcessWindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
Modifier and Type | Method and Description |
---|---|
void |
StreamExecutionEnvironment.addOperator(Transformation<?> transformation)
Adds an operator to the list of operators that should be executed when calling
StreamExecutionEnvironment.execute() . |
<F> F |
StreamExecutionEnvironment.clean(F f)
Returns a "closure-cleaned" version of the given function.
|
JobExecutionResult |
StreamExecutionEnvironment.execute(StreamGraph streamGraph)
Triggers the program execution.
|
JobClient |
StreamExecutionEnvironment.executeAsync(StreamGraph streamGraph)
Triggers the program execution asynchronously.
|
StreamGraph |
StreamExecutionEnvironment.getStreamGraph()
Getter of the
StreamGraph of the streaming job. |
StreamGraph |
StreamExecutionEnvironment.getStreamGraph(String jobName)
Getter of the
StreamGraph of the streaming job. |
StreamGraph |
StreamExecutionEnvironment.getStreamGraph(String jobName,
boolean clearTransformations)
Getter of the
StreamGraph of the
streaming job with the option to clear previously registered transformations . |
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 |
Comparator
Internal comparator implementation, for use with
ComparableAggregator . |
class |
SumAggregator<T>
An
AggregationFunction that sums up fields. |
class |
SumFunction
Internal function for summing up contents of fields.
|
Modifier and Type | Class and Description |
---|---|
class |
DataStreamPythonFunction
DataStreamPythonFunction maintains the serialized python function which will be used in
BeamDataStreamPythonFunctionRunner. |
class |
DataStreamPythonFunctionInfo
DataStreamPythonFunctionInfo holds a PythonFunction and its function type. |
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 |
QueryableAppendingStateOperator<IN>
Internal operator handling queryable AppendingState instances.
|
class |
QueryableValueStateOperator<IN>
Internal operator handling queryable ValueState instances.
|
Modifier and Type | Class and Description |
---|---|
class |
SinkContextUtil
Utility for creating Sink
Contexts . |
static class |
TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>
State POJO class coupling pendingTransaction, context and pendingCommitTransactions.
|
static class |
TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT>
Custom
TypeSerializer for the sink state. |
static class |
TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot<TXN,CONTEXT>
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards
compatibility purposes. It is fully replaced by
TwoPhaseCommitSinkFunction.StateSerializerSnapshot . |
static class |
TwoPhaseCommitSinkFunction.StateSerializerSnapshot<TXN,CONTEXT>
Snapshot for the
TwoPhaseCommitSinkFunction.StateSerializer . |
static class |
TwoPhaseCommitSinkFunction.TransactionHolder<TXN>
Adds metadata (currently only the start time of the transaction) to the transaction object.
|
Modifier and Type | Class and Description |
---|---|
class |
Bucket<IN,BucketID>
A bucket is the directory organization of the output of the
StreamingFileSink . |
interface |
BucketFactory<IN,BucketID>
A factory able to create
buckets for the StreamingFileSink . |
interface |
BucketLifeCycleListener<IN,BucketID>
Listener about the status of
Bucket . |
class |
Buckets<IN,BucketID>
The manager of the different active buckets in the
StreamingFileSink . |
interface |
BucketWriter<IN,BucketID>
An interface for factories that create the different
writers . |
class |
BulkBucketWriter<IN,BucketID>
A factory that creates
BulkPartWriters . |
class |
DefaultBucketFactoryImpl<IN,BucketID>
A factory returning
buckets . |
interface |
FileLifeCycleListener<BucketID>
Listener about the status of file.
|
interface |
InProgressFileWriter<IN,BucketID>
The
Bucket uses the InProgressFileWriter to write element to a part file. |
class |
RowWiseBucketWriter<IN,BucketID>
A factory that creates
RowWisePartWriters . |
static class |
StreamingFileSink.BucketsBuilder<IN,BucketID,T extends StreamingFileSink.BucketsBuilder<IN,BucketID,T>>
The base abstract class for the
StreamingFileSink.RowFormatBuilder and StreamingFileSink.BulkFormatBuilder . |
class |
StreamingFileSinkHelper<IN>
Helper for
StreamingFileSink . |
class |
WriterProperties
This class describes the property of the
BucketWriter . |
Modifier and Type | Method and Description |
---|---|
abstract Buckets<IN,BucketID> |
StreamingFileSink.BucketsBuilder.createBuckets(int subtaskIndex) |
Buckets<IN,BucketID> |
StreamingFileSink.RowFormatBuilder.createBuckets(int subtaskIndex) |
Buckets<IN,BucketID> |
StreamingFileSink.BulkFormatBuilder.createBuckets(int subtaskIndex) |
abstract BucketWriter<IN,BucketID> |
StreamingFileSink.BucketsBuilder.createBucketWriter() |
BucketWriter<IN,BucketID> |
StreamingFileSink.RowFormatBuilder.createBucketWriter() |
BucketWriter<IN,BucketID> |
StreamingFileSink.BulkFormatBuilder.createBucketWriter() |
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 |
ContinuousFileReaderOperator<OUT,T extends TimestampedInputSplit>
The operator that reads the
splits received from the preceding
ContinuousFileMonitoringFunction . |
class |
FileMonitoringFunction
Deprecated.
Internal class deprecated in favour of
ContinuousFileMonitoringFunction . |
class |
FileReadFunction
Deprecated.
Internal class deprecated in favour of
ContinuousFileMonitoringFunction . |
class |
InputFormatSourceFunction<OUT>
A
SourceFunction that reads data using an InputFormat . |
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 |
InternalProcessApplyAllWindowContext<IN,OUT,W extends Window>
Internal reusable context wrapper.
|
class |
InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window>
Internal reusable context wrapper.
|
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 |
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 . |
Modifier and Type | Class and Description |
---|---|
class |
ArrayFromTuple
Converts a Tuple to an Object-Array.
|
class |
ConcatenatedExtract<FROM,OVER,TO>
Combines two extractors which will be executed one after each other.
|
interface |
Extractor<FROM,TO>
Extractors allow to extract/convert one type to another.
|
class |
FieldFromArray<OUT>
Extracts a single field out of an array.
|
class |
FieldFromTuple<OUT>
Extracts a single field out of a tuple.
|
class |
FieldsFromArray<OUT>
Extracts multiple fields from an array and puts them into a new array of the specified type.
|
class |
FieldsFromTuple
Extracts one or more fields of the type Double from a tuple and puts them into a new double[].
|
Modifier and Type | Class and Description |
---|---|
class |
JSONGenerator
Helper class for generating a JSON representation from a
StreamGraph . |
class |
SimpleTransformationTranslator<OUT,T extends Transformation<OUT>>
A base class for all
TransformationTranslators who translate
Transformations that have a single operator in their runtime
implementation. |
class |
StreamConfig
Internal configuration for a
StreamOperator . |
class |
StreamEdge
An edge in the streaming topology.
|
class |
StreamGraph
Class representing the streaming topology.
|
class |
StreamGraphGenerator
A generator that generates a
StreamGraph from a graph of Transformation s. |
class |
StreamingJobGraphGenerator
The StreamingJobGraphGenerator converts a
StreamGraph into a JobGraph . |
class |
StreamNode
Class representing the operators in the streaming programs, with all their properties.
|
interface |
TransformationTranslator<OUT,T extends Transformation<OUT>>
A
TransformationTranslator is responsible for translating a given Transformation
to its runtime implementation depending on the execution mode. |
Modifier and Type | Class and Description |
---|---|
class |
BatchGroupedReduceOperator<IN,KEY>
A
StreamOperator for executing a ReduceFunction on a KeyedStream in a RuntimeExecutionMode.BATCH
mode. |
interface |
InputFormatOperatorFactory<OUT>
Input format source operator factory.
|
interface |
InternalTimer<K,N>
Internal interface for in-flight timers.
|
interface |
InternalTimerService<N>
Interface for working with time and timers.
|
class |
InternalTimerServiceSerializationProxy<K>
Serialization proxy for the timer services for a given key-group.
|
class |
InternalTimersSnapshotReaderWriters
Readers and writers for different versions of the
InternalTimersSnapshot . |
interface |
InternalTimeServiceManager<K>
An entity keeping all the time-related services.
|
class |
InternalTimeServiceManagerImpl<K>
An entity keeping all the time-related services.
|
class |
KeyedProcessOperator<K,IN,OUT>
A
StreamOperator for executing KeyedProcessFunctions . |
class |
LegacyKeyedProcessOperator<K,IN,OUT>
Deprecated.
Replaced by
KeyedProcessOperator which takes KeyedProcessFunction |
interface |
OnWatermarkCallback<KEY>
A callback registered with the
InternalWatermarkCallbackService service. |
interface |
OutputFormatOperatorFactory<IN>
Interface for operator factories which create the sink operator containing an
OutputFormat . |
class |
ProcessOperator<IN,OUT>
A
StreamOperator for executing ProcessFunctions . |
class |
SimpleInputFormatOperatorFactory<OUT>
Input format source operator factory which just wrap existed
StreamSource . |
class |
SimpleOperatorFactory<OUT>
Simple factory which just wrap existed
StreamOperator . |
class |
SimpleOutputFormatOperatorFactory<IN>
A simple operator factory which create
StreamSink containing an OutputFormat . |
class |
SimpleUdfStreamOperatorFactory<OUT>
Udf stream operator factory which just wrap existed
AbstractUdfStreamOperator . |
class |
SourceOperator<OUT,SplitT extends SourceSplit>
Base source operator only used for integrating the source reader which is proposed by FLIP-27.
|
class |
StreamFilter<IN>
A
StreamOperator for executing FilterFunctions . |
class |
StreamFlatMap<IN,OUT>
A
StreamOperator for executing FlatMapFunctions . |
class |
StreamGroupedReduceOperator<IN>
|
class |
StreamingRuntimeContext
Implementation of the
RuntimeContext , for streaming
operators. |
class |
StreamMap<IN,OUT>
A
StreamOperator for executing MapFunctions . |
class |
StreamOperatorStateHandler
Class encapsulating various state backend handling logic for
StreamOperator
implementations. |
class |
StreamProject<IN,OUT extends Tuple>
A
StreamOperator for executing projections on streams. |
class |
StreamSink<IN>
A
StreamOperator for executing SinkFunctions . |
class |
StreamSource<OUT,SRC extends SourceFunction<OUT>>
StreamOperator for streaming sources. |
class |
TimerHeapInternalTimer<K,N>
Implementation of
InternalTimer to use with a HeapPriorityQueueSet . |
class |
TimerSerializer<K,N>
A serializer for
TimerHeapInternalTimer objects that produces a serialization format that
is lexicographically aligned the priority of the timers. |
class |
TimerSerializerSnapshot<K,N>
Snapshot class for the
TimerSerializer . |
class |
TimestampedCollector<T>
|
interface |
Triggerable<K,N>
Interface for things that can be called by
InternalTimerService . |
interface |
UdfStreamOperatorFactory<OUT>
Udf stream operator factory.
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
AbstractStreamOperator.isUsingCustomRawKeyedState()
Indicates whether or not implementations of this class is writing to the raw keyed state
streams on snapshots, using
AbstractStreamOperator.snapshotState(StateSnapshotContext) . |
protected boolean |
AbstractStreamOperatorV2.isUsingCustomRawKeyedState()
Indicates whether or not implementations of this class is writing to the raw keyed state
streams on snapshots, using
AbstractStreamOperatorV2.snapshotState(StateSnapshotContext) . |
Modifier and Type | Class and Description |
---|---|
class |
AsyncWaitOperator<IN,OUT>
The
AsyncWaitOperator allows to asynchronously process incoming stream records. |
Modifier and Type | Class and Description |
---|---|
class |
OrderedStreamElementQueue<OUT>
Ordered
StreamElementQueue implementation. |
interface |
StreamElementQueue<OUT>
Interface for stream element queues for the
AsyncWaitOperator . |
class |
UnorderedStreamElementQueue<OUT>
Unordered implementation of the
StreamElementQueue . |
Modifier and Type | Class and Description |
---|---|
class |
ClientAndIterator<E>
|
class |
CollectSinkFunction<IN>
A sink function that collects query results and sends them back to the client.
|
class |
CollectStreamSink<T>
A
DataStreamSink which is used to collect results of a data stream. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractOneInputPythonFunctionOperator<IN,OUT>
Base class for all one input stream operators to execute Python functions.
|
class |
AbstractPythonFunctionOperator<OUT>
Base class for all stream operators to execute Python functions.
|
class |
AbstractTwoInputPythonFunctionOperator<IN1,IN2,OUT>
Base class for all two input stream operators to execute Python functions.
|
class |
OneInputPythonFunctionOperator<IN,OUT,UDFIN,UDFOUT>
OneInputPythonFunctionOperator is responsible for launching beam runner which will start
a python harness to execute user defined python function. |
class |
PythonCoFlatMapOperator<IN1,IN2,OUT>
The
PythonCoFlatMapOperator is responsible for executing the Python CoMap Function. |
class |
PythonCoMapOperator<IN1,IN2,OUT>
The
PythonCoFlatMapOperator is responsible for executing the Python CoMap Function. |
class |
PythonFlatMapOperator<IN,OUT>
The
PythonFlatMapOperator is responsible for executing Python functions that gets one
input and produces zero/one or more outputs. |
class |
PythonKeyedProcessOperator<OUT>
PythonKeyedProcessOperator is responsible for launching beam runner which will start a
python harness to execute user defined python function. |
class |
PythonMapOperator<IN,OUT>
The
PythonMapOperator is responsible for executing Python functions that gets one input
and produces zero/one or more outputs. |
class |
PythonPartitionCustomOperator<IN,OUT>
The
PythonPartitionCustomOperator enables us to set the number of partitions for current
operator dynamically when generating the StreamGraph
before executing the job. |
class |
PythonProcessOperator<IN,OUT>
PythonProcessOperator is responsible for launching beam runner which will start a python
harness to execute user defined python ProcessFunction. |
class |
PythonTimestampsAndWatermarksOperator<IN>
A stream operator that may do one or both of the following: extract timestamps from events and
generate watermarks by user specify TimestampAssigner and WatermarkStrategy.
|
class |
TwoInputPythonFunctionOperator<IN1,IN2,RUNNER_OUT,OUT>
TwoInputPythonFunctionOperator is responsible for launching beam runner which will start
a python harness to execute two-input user defined python function. |
Modifier and Type | Class and Description |
---|---|
class |
NoOpTimestampsAndWatermarks<T>
An implementation of
TimestampsAndWatermarks where all watermarking/event-time operations
are no-ops. |
class |
ProgressiveTimestampsAndWatermarks<T>
An implementation of
TimestampsAndWatermarks that does periodic watermark emission and
keeps track of watermarks on a per-split basis. |
class |
SourceOutputWithWatermarks<T>
Implementation of the SourceOutput.
|
interface |
TimestampsAndWatermarks<T>
Basic interface for the timestamp extraction and watermark generation logic for the
SourceReader . |
class |
TimestampsAndWatermarksContext
A simple implementation of a context that is both
TimestampAssignerSupplier.Context and
WatermarkGeneratorSupplier.Context . |
class |
WatermarkToDataOutput
An adapter that exposes a
WatermarkOutput based on a PushingAsyncDataInput.DataOutput . |
Modifier and Type | Class and Description |
---|---|
class |
BeamDataStreamPythonFunctionRunner
BeamDataStreamPythonFunctionRunner is responsible for starting a beam python harness to
execute user defined python function. |
class |
BeamPythonFunctionRunner
A
BeamPythonFunctionRunner used to execute Python functions. |
class |
PythonSharedResources
The set of resources that can be shared by all the Python operators in a slot.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractBroadcastStateTransformation<IN1,IN2,OUT>
Base class for Broadcast State transformations.
|
class |
AbstractMultipleInputTransformation<OUT>
Base class for transformations representing the application of a
MultipleInputStreamOperator to input Transformations . |
class |
BroadcastStateTransformation<IN1,IN2,OUT>
A non-keyed
AbstractBroadcastStateTransformation . |
class |
CoFeedbackTransformation<F>
This represents a feedback point in a topology.
|
class |
FeedbackTransformation<T>
This represents a feedback point in a topology.
|
class |
KeyedBroadcastStateTransformation<KEY,IN1,IN2,OUT>
A keyed
AbstractBroadcastStateTransformation . |
class |
KeyedMultipleInputTransformation<OUT>
AbstractMultipleInputTransformation implementation for keyed streams. |
class |
LegacySinkTransformation<T>
This Transformation represents a stream Sink.
|
class |
LegacySourceTransformation<T>
This represents a Source.
|
class |
MultipleInputTransformation<OUT>
AbstractMultipleInputTransformation implementation for non-keyed streams. |
class |
OneInputTransformation<IN,OUT>
This Transformation represents the application of a
OneInputStreamOperator to one input Transformation . |
class |
PartitionTransformation<T>
This transformation represents a change of partitioning of the input elements.
|
class |
PhysicalTransformation<T>
A
Transformation that creates a physical operation. |
class |
ReduceTransformation<IN,K>
A
Transformation that describes a reduce operation on a KeyedStream . |
class |
SinkTransformation<InputT,CommT,WriterStateT,GlobalCommT>
A
Transformation for Sink . |
class |
SourceTransformation<OUT,SplitT extends SourceSplit,EnumChkT>
A
PhysicalTransformation for Source . |
class |
TimestampsAndWatermarksTransformation<IN>
|
class |
TwoInputTransformation<IN1,IN2,OUT>
This Transformation represents the application of a
TwoInputStreamOperator to two input
Transformations . |
class |
UnionTransformation<T>
This transformation represents a union of several input
Transformations . |
interface |
WithBoundedness
An interface to be implemented by transformations that have explicitly set
Boundedness . |
Modifier and Type | Class and Description |
---|---|
class |
PickledByteArrayTypeInfo
A PickledByteArrayTypeInfo indicates that the data of this type is a generated primitive byte
array by pickle.
|
Modifier and Type | Class and Description |
---|---|
class |
ByteArrayWrapper
A wrapper of the byte array.
|
class |
ByteArrayWrapperSerializer
The serializer of
ByteArrayWrapper . |
class |
PythonTypeUtils
A util class for converting the given TypeInformation to other objects.
|
Modifier and Type | Class and Description |
---|---|
static class |
GlobalWindows.NeverTrigger
A trigger that never fires, as default Trigger for GlobalWindows.
|
Modifier and Type | Class and Description |
---|---|
class |
NoOpCassandraFailureHandler
A
CassandraFailureHandler that simply fails the sink on any failures. |
Modifier and Type | Interface and Description |
---|---|
interface |
ElasticsearchApiCallBridge<C extends AutoCloseable>
An
ElasticsearchApiCallBridge is used to bridge incompatible Elasticsearch Java API calls
across different versions. |
class |
ElasticsearchSinkBase<T,C extends AutoCloseable>
Base class for all Flink Elasticsearch Sinks.
|
class |
ElasticsearchUpsertTableSinkBase
A version-agnostic Elasticsearch
UpsertStreamTableSink . |
class |
ElasticsearchUpsertTableSinkFactoryBase
Version-agnostic table factory for creating an
UpsertStreamTableSink for Elasticsearch. |
Modifier and Type | Interface and Description |
---|---|
interface |
IndexGenerator
This interface is responsible to generate index name from given
Row record. |
class |
IndexGeneratorFactory
Factory of
IndexGenerator . |
Modifier and Type | Class and Description |
---|---|
class |
Elasticsearch6DynamicSinkFactory
A
DynamicTableSinkFactory for discovering Elasticsearch6DynamicSink . |
class |
Elasticsearch7DynamicSinkFactory
A
DynamicTableSinkFactory for discovering Elasticsearch7DynamicSink . |
class |
IndexGeneratorBase
Base class for
IndexGenerator . |
Modifier and Type | Class and Description |
---|---|
class |
ElasticsearchUtils
Suite of utility methods for Elasticsearch.
|
class |
IgnoringFailureHandler
Ignores all kinds of failures and drops the affected
ActionRequest . |
class |
NoOpFailureHandler
An
ActionRequestFailureHandler that simply fails the sink on any failures. |
Modifier and Type | Class and Description |
---|---|
class |
Elasticsearch5ApiCallBridge
Implementation of
ElasticsearchApiCallBridge for Elasticsearch 5.x. |
Modifier and Type | Class and Description |
---|---|
class |
Elasticsearch6ApiCallBridge
Implementation of
ElasticsearchApiCallBridge for Elasticsearch 6 and later versions. |
class |
Elasticsearch6UpsertTableSink
Version-specific upsert table sink for Elasticsearch 6.
|
class |
Elasticsearch6UpsertTableSinkFactory
Table factory for creating an
UpsertStreamTableSink for Elasticsearch 6. |
Modifier and Type | Class and Description |
---|---|
class |
Elasticsearch7ApiCallBridge
Implementation of
ElasticsearchApiCallBridge for Elasticsearch 7 and later versions. |
class |
Elasticsearch7UpsertTableSink
Version-specific upsert table sink for Elasticsearch 7.
|
class |
Elasticsearch7UpsertTableSinkFactory
Table factory for creating an
UpsertStreamTableSink for Elasticsearch 7. |
Modifier and Type | Class and Description |
---|---|
class |
FlinkKafkaConsumerBase<T>
Base class of all Flink Kafka Consumer data sources.
|
static class |
FlinkKafkaProducer.ContextStateSerializer
|
static class |
FlinkKafkaProducer.KafkaTransactionContext
Context associated to this instance of the
FlinkKafkaProducer . |
static class |
FlinkKafkaProducer.KafkaTransactionState
State for handling transactions.
|
static class |
FlinkKafkaProducer.NextTransactionalIdHintSerializer
|
static class |
FlinkKafkaProducer.TransactionStateSerializer
|
class |
FlinkKafkaProducerBase<IN>
Flink Sink to produce data into a Kafka topic.
|
class |
KafkaTableSink
Deprecated.
Use
KafkaDynamicSink via KafkaDynamicTableFactory . |
class |
KafkaTableSinkBase
Deprecated.
Use
KafkaDynamicSink via KafkaDynamicTableFactory . |
class |
KafkaTableSource
Deprecated.
|
class |
KafkaTableSourceBase
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
OffsetCommitMode
The offset commit mode represents the behaviour of how offsets are externally committed back to
Kafka brokers / Zookeeper.
|
class |
OffsetCommitModes
Utilities for
OffsetCommitMode . |
class |
StartupMode
Startup modes for the Kafka Consumer.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractFetcher<T,KPH>
Base class for all fetchers, which implement the connections to Kafka brokers and pull records
from Kafka partitions.
|
class |
AbstractPartitionDiscoverer
Base class for all partition discoverers.
|
class |
ClosableBlockingQueue<E>
A special form of blocking queue with two additions:
The queue can be closed atomically when empty.
|
class |
ExceptionProxy
A proxy that communicates exceptions between threads.
|
class |
Handover
The Handover is a utility to hand over data (a buffer of records) and exception from a
producer thread to a consumer thread.
|
interface |
KafkaCommitCallback
A callback interface that the source operator can implement to trigger custom actions when a
commit request completes, which should normally be triggered from checkpoint complete event.
|
class |
KafkaConsumerThread<T>
The thread the runs the
KafkaConsumer , connecting to the brokers and polling records. |
class |
KafkaDeserializationSchemaWrapper<T>
A simple wrapper for using the DeserializationSchema with the KafkaDeserializationSchema
interface.
|
class |
KafkaFetcher<T>
A fetcher that fetches data from Kafka brokers via the Kafka consumer API.
|
class |
KafkaPartitionDiscoverer
A partition discoverer that can be used to discover topics and partitions metadata from Kafka
brokers via the Kafka high-level consumer API.
|
class |
KafkaSerializationSchemaWrapper<T>
An adapter from old style interfaces such as
SerializationSchema , FlinkKafkaPartitioner to the KafkaSerializationSchema . |
class |
KafkaShuffleFetcher<T>
Fetch data from Kafka for Kafka Shuffle.
|
class |
KafkaTopicPartitionAssigner
Utility for assigning Kafka partitions to consumer subtasks.
|
class |
KafkaTopicPartitionLeader
Serializable Topic Partition info with leader Node information.
|
class |
KafkaTopicPartitionState<T,KPH>
The state that the Flink Kafka Consumer holds for each Kafka partition.
|
class |
KafkaTopicPartitionStateSentinel
Magic values used to represent special offset states before partitions are actually read.
|
class |
KafkaTopicPartitionStateWithWatermarkGenerator<T,KPH>
A special version of the per-kafka-partition-state that additionally holds a
TimestampAssigner , WatermarkGenerator , an immediate WatermarkOutput , and a
deferred WatermarkOutput for this partition. |
class |
KafkaTopicsDescriptor
A Kafka Topics Descriptor describes how the consumer subscribes to Kafka topics - either a fixed
list of topics, or a topic pattern.
|
class |
KeyedSerializationSchemaWrapper<T>
A simple wrapper for using the SerializationSchema with the KeyedSerializationSchema interface.
|
class |
TransactionalIdsGenerator
Class responsible for generating transactional ids to use when communicating with Kafka.
|
Modifier and Type | Class and Description |
---|---|
class |
KafkaConsumerMetricConstants
A collection of Kafka consumer metrics related constant strings.
|
class |
KafkaMetricMutableWrapper
Gauge for getting the current value of a Kafka metric.
|
class |
KafkaMetricWrapper
Gauge for getting the current value of a Kafka metric.
|
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 |
KafkaDynamicSink
A version-agnostic Kafka
DynamicTableSink . |
class |
KafkaDynamicSource
A version-agnostic Kafka
ScanTableSource . |
class |
KafkaDynamicTableFactory
Factory for creating configured instances of
KafkaDynamicSource and KafkaDynamicSink . |
class |
KafkaSinkSemantic
Kafka sink semantic Enum.
|
Modifier and Type | Class and Description |
---|---|
class |
FlinkKinesisException
A
RuntimeException wrapper indicating the exception was thrown from this connector. |
static class |
FlinkKinesisException.FlinkKinesisTimeoutException
A semantic
RuntimeException thrown to indicate timeout errors in the Kinesis
connector. |
Modifier and Type | Class and Description |
---|---|
class |
KinesisDataFetcher<T>
A KinesisDataFetcher is responsible for fetching data from multiple Kinesis shards.
|
class |
ShardConsumer<T>
Thread that subscribes to the given
RecordPublisher . |
Modifier and Type | Class and Description |
---|---|
class |
RecordBatch
A batch of UserRecords received from Kinesis.
|
interface |
RecordPublisher
A
RecordPublisher will consume records from an external stream and deliver them to the
registered subscriber. |
interface |
RecordPublisherFactory
A factory interface used to create instances of
RecordPublisher . |
Modifier and Type | Class and Description |
---|---|
class |
FanOutRecordPublisher
A
RecordPublisher that will read and forward records from Kinesis using EFO, to the
subscriber. |
class |
FanOutRecordPublisherFactory
A
RecordPublisher factory used to create instances of FanOutRecordPublisher . |
class |
FanOutShardSubscriber
This class is responsible for acquiring an Enhanced Fan Out subscription and consuming records
from a shard.
|
class |
StreamConsumerRegistrar
Responsible for registering and deregistering EFO stream consumers.
|
Modifier and Type | Class and Description |
---|---|
class |
AdaptivePollingRecordPublisher
An adaptive record publisher to add a dynamic batch read size for
PollingRecordPublisher . |
class |
PollingRecordPublisher
A
RecordPublisher that will read records from Kinesis and forward them to the subscriber. |
class |
PollingRecordPublisherConfiguration
A configuration class for
PollingRecordPublisher instantiated from a properties map. |
class |
PollingRecordPublisherFactory
A
RecordPublisher factory used to create instances of PollingRecordPublisher . |
Modifier and Type | Class and Description |
---|---|
class |
KinesisConsumerMetricConstants
A collection of consumer metric related constant names.
|
class |
PollingRecordPublisherMetricsReporter
A container for
PollingRecordPublisher s to report metric values. |
class |
ShardConsumerMetricsReporter
A container for
ShardConsumer s to report metric values. |
Modifier and Type | Class and Description |
---|---|
class |
KinesisStreamShard
Deprecated.
Will be remove in a future version in favor of
StreamShardHandle . |
class |
KinesisStreamShardState
A wrapper class that bundles a
StreamShardHandle with its last processed sequence number. |
class |
SentinelSequenceNumber
Special flag values for sequence numbers in shards to indicate special positions.
|
class |
SequenceNumber
A serializable representation of a Kinesis record's sequence number.
|
class |
StartingPosition
The position in which to start consuming from a stream.
|
class |
StreamShardHandle
A wrapper class around the information provided along with streamName and
Shard , with some extra utility methods to determine whether
or not a shard is closed and whether or not the shard is a result of parent shard splits or
merges. |
class |
StreamShardMetadata
A serializable representation of a AWS Kinesis Stream shard.
|
Modifier and Type | Class and Description |
---|---|
class |
FullJitterBackoff
Used to calculate full jitter backoff sleep durations.
|
class |
GetShardListResult
Basic model class to bundle the shards retrieved from Kinesis on a
KinesisProxyInterface.getShardList(Map) call. |
class |
KinesisProxy
Kinesis proxy implementation - a utility class that is used as a proxy to make calls to AWS
Kinesis for several functions, such as getting a list of shards and fetching a batch of data
records starting from a specified record sequence number.
|
interface |
KinesisProxyInterface
Interface for a Kinesis proxy that operates on multiple Kinesis streams within the same AWS
service region.
|
class |
KinesisProxyV2
Kinesis proxy implementation using AWS SDK v2.x - a utility class that is used as a proxy to make
calls to AWS Kinesis for several EFO (Enhanced Fan Out) functions, such as de-/registering stream
consumers, subscribing to a shard and receiving records from a shard.
|
class |
KinesisProxyV2Factory
Creates instances of
KinesisProxyV2 . |
interface |
KinesisProxyV2Interface
Interface for a Kinesis proxy using AWS SDK v2.x operating on multiple Kinesis streams within the
same AWS service region.
|
Modifier and Type | Class and Description |
---|---|
class |
KinesisDeserializationSchemaWrapper<T>
A simple wrapper for using the
DeserializationSchema with the KinesisDeserializationSchema interface. |
Modifier and Type | Class and Description |
---|---|
class |
KinesisDynamicSink
Kinesis-backed
DynamicTableSink . |
class |
KinesisDynamicSource
Kinesis-backed
ScanTableSource . |
class |
KinesisDynamicTableFactory
Factory for creating
KinesisDynamicSource and KinesisDynamicSink instances. |
class |
KinesisOptions
Options for Kinesis tables supported by the {@code CREATE TABLE ...
|
class |
RowDataFieldsKinesisPartitioner
A
KinesisPartitioner of RowData elements that constructs the partition key from a
list of field names. |
class |
RowDataKinesisDeserializationSchema
A
KinesisDeserializationSchema adaptor for RowData records that delegates
physical data deserialization to an inner DeserializationSchema and appends requested
metadata to the end of the deserialized RowData record. |
Modifier and Type | Class and Description |
---|---|
class |
AWSUtil
Some utilities specific to Amazon Web Service.
|
class |
AwsV2Util
Utility methods specific to Amazon Web Service SDK v2.x.
|
class |
KinesisConfigUtil
Utilities for Flink Kinesis connector configuration.
|
class |
RecordEmitter<T extends TimestampedValue>
Emitter that handles event time synchronization between producer threads.
|
class |
StreamConsumerRegistrarUtil
A utility class that creates instances of
StreamConsumerRegistrar and handles batch
operations. |
static class |
StreamConsumerRegistrarUtil.FlinkKinesisStreamConsumerRegistrarException
A semantic
RuntimeException thrown to indicate errors de-/registering stream
consumers. |
class |
TimeoutLatch
Internal use.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractDataOutput<T>
Base class for all data outputs.
|
class |
BlockingQueueBroker
Broker for the BlockingQueue used in StreamIterationHead and StreamIterationTail for implementing feedback streams. |
class |
InputGateUtil
Utility for dealing with input gates.
|
class |
MultipleInputSelectionHandler
This handler is mainly used for selecting the next available input index in
StreamMultipleInputProcessor . |
interface |
PushingAsyncDataInput<T>
The variant of
PullingAsyncDataInput that is defined for handling both network input and
source input in a unified way via PushingAsyncDataInput.emitNext(DataOutput) instead of returning Optional.empty() via PullingAsyncDataInput.pollNext() . |
class |
RecordWriterOutput<OUT>
Implementation of
Output that sends data using a RecordWriter . |
interface |
StreamInputProcessor
Interface for processing records by
StreamTask . |
class |
StreamMultipleInputProcessor
Input processor for
MultipleInputStreamOperator . |
class |
StreamMultipleInputProcessorFactory
A factory for
StreamMultipleInputProcessor . |
class |
StreamOneInputProcessor<IN>
Input reader for
OneInputStreamTask . |
interface |
StreamTaskInput<T>
Basic interface for inputs of stream operators.
|
class |
StreamTaskNetworkInput<T>
Implementation of
StreamTaskInput that wraps an input from network taken from CheckpointedInputGate . |
class |
StreamTaskSourceInput<T>
Implementation of
StreamTaskInput that reads data from the SourceOperator and
returns the InputStatus to indicate whether the source state is available, unavailable or
finished. |
class |
StreamTwoInputProcessor<IN1,IN2>
Input reader for
TwoInputStreamTask . |
class |
TwoInputSelectionHandler
This handler is mainly used for selecting the next available input index in
StreamTwoInputProcessor . |
Modifier and Type | Class and Description |
---|---|
class |
CheckpointBarrierTracker
The
CheckpointBarrierTracker keeps track of what checkpoint barriers have been received
from which input channels. |
class |
CheckpointedInputGate
The
CheckpointedInputGate uses CheckpointBarrierHandler to handle incoming CheckpointBarrier from the InputGate . |
class |
InputProcessorUtil
Utility for creating
CheckpointedInputGate based on checkpoint mode for StreamOneInputProcessor and StreamTwoInputProcessor . |
class |
SingleCheckpointBarrierHandler
SingleCheckpointBarrierHandler is used for triggering checkpoint while reading the first
barrier and keeping track of the number of received barriers and consumed barriers. |
interface |
UpstreamRecoveryTracker
Tracks status of upstream channels while they recover.
|
Modifier and Type | Class and Description |
---|---|
class |
RescalingStreamTaskNetworkInput<T>
A
StreamTaskNetworkInput implementation that demultiplexes virtual channels. |
Modifier and Type | Class and Description |
---|---|
class |
CommittableTypeInformation<CommT>
A
TypeInformation for Sink 's committable,
which uses the SimpleVersionedSerializer to serialize the object. |
class |
StreamingCommitterOperatorFactory<CommT>
A
StreamOperatorFactory for StreamingCommitterOperator . |
class |
StreamingGlobalCommitterOperator<CommT,GlobalCommT>
Runtime
StreamOperator for executing GlobalCommitter in the streaming execution mode. |
Modifier and Type | Class and Description |
---|---|
class |
AssignerWithPeriodicWatermarksAdapter<T>
An adapter that wraps a
AssignerWithPeriodicWatermarks into a WatermarkGenerator . |
class |
AssignerWithPunctuatedWatermarksAdapter<T>
An adapter that wraps a
AssignerWithPunctuatedWatermarks into a WatermarkGenerator . |
Modifier and Type | Class and Description |
---|---|
class |
EvictingWindowOperator<K,IN,OUT,W extends Window>
A
WindowOperator that also allows an Evictor to be used. |
class |
KeyMap<K,V>
A special Hash Map implementation that can be traversed efficiently in sync with other hash maps.
|
class |
WindowOperator<K,IN,ACC,OUT,W extends Window>
An operator that implements the logic for windowing based on a
WindowAssigner and Trigger . |
Modifier and Type | Class and Description |
---|---|
class |
InternalProcessAllWindowContext<IN,OUT,W extends Window>
Internal reusable context wrapper.
|
class |
InternalProcessWindowContext<IN,OUT,KEY,W extends Window>
Internal reusable context wrapper.
|
Modifier and Type | Class and Description |
---|---|
class |
BroadcastPartitioner<T>
Partitioner that selects all the output channels.
|
class |
CustomPartitionerWrapper<K,T>
Partitioner that selects the channel with a user defined partitioner function on a key.
|
class |
ForwardPartitioner<T>
Partitioner that forwards elements only to the locally running downstream operation.
|
class |
GlobalPartitioner<T>
Partitioner that sends all elements to the downstream operator with subtask ID=0.
|
class |
KeyGroupStreamPartitioner<T,K>
Partitioner selects the target channel based on the key group index.
|
class |
RebalancePartitioner<T>
Partitioner that distributes the data equally by cycling through the output channels.
|
class |
RescalePartitioner<T>
Partitioner that distributes the data equally by cycling through the output channels.
|
class |
ShufflePartitioner<T>
Partitioner that distributes the data equally by selecting one output channel randomly.
|
class |
StreamPartitioner<T>
A special
ChannelSelector for use in streaming programs. |
Modifier and Type | Class and Description |
---|---|
class |
StreamElement
An element in a data stream.
|
class |
StreamElementSerializer<T>
|
class |
StreamRecord<T>
One value in a data stream.
|
Modifier and Type | Class and Description |
---|---|
class |
StatusWatermarkValve
A
StatusWatermarkValve embodies the logic of how Watermark and StreamStatus are propagated to downstream outputs, given a set of one or multiple input channels
that continuously receive them. |
class |
StreamStatus
A Stream Status element informs stream tasks whether or not they should continue to expect
records and watermarks from the input stream that sent them.
|
interface |
StreamStatusMaintainer
Interface that allows toggling the current
StreamStatus as well as retrieving it. |
interface |
StreamStatusProvider
Interface for retrieving the current
StreamStatus . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractTwoInputStreamTask<IN1,IN2,OUT>
Abstract class for executing a
TwoInputStreamOperator . |
class |
AsynchronousException
An exception for wrapping exceptions that are thrown by an operator in threads other than the
main compute thread of that operator.
|
class |
ExceptionInChainedOperatorException
A special exception that signifies that the cause exception came from a chained operator.
|
class |
MultipleInputStreamTask<OUT>
A
StreamTask for executing a MultipleInputStreamOperator and supporting the
MultipleInputStreamOperator to select input for reading. |
class |
OneInputStreamTask<IN,OUT>
A
StreamTask for executing a OneInputStreamOperator . |
class |
OperatorChain<OUT,OP extends StreamOperator<OUT>>
The
OperatorChain contains all operators that are executed as one chain within a single
StreamTask . |
class |
OperatorEventDispatcherImpl
An implementation of the
OperatorEventDispatcher . |
interface |
ProcessingTimeCallback
Interface for processing-time callbacks that can be registered at a
ProcessingTimeService . |
interface |
ProcessingTimeServiceFactory
A factory for creating processing time services with a given
MailboxExecutor . |
class |
ProcessingTimeServiceUtil
Utility for classes that implements the
ProcessingTimeService interface. |
class |
SourceOperatorStreamTask<T>
A subclass of
StreamTask for executing the SourceOperator . |
class |
SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>>
StreamTask for executing a StreamSource . |
class |
StreamIterationHead<OUT>
A special
StreamTask that is used for executing feedback edges. |
class |
StreamIterationTail<IN>
A special
StreamTask that is used for executing feedback edges. |
class |
StreamOperatorWrapper<OUT,OP extends StreamOperator<OUT>>
This class handles the close, endInput and other related logic of a
StreamOperator . |
class |
StreamTask<OUT,OP extends StreamOperator<OUT>>
Base class for all streaming tasks.
|
interface |
StreamTaskActionExecutor
|
class |
StreamTaskException
An exception that is thrown by the stream vertices when encountering an illegal condition.
|
interface |
SubtaskCheckpointCoordinator
Coordinates checkpointing-related work for a subtask (i.e.
|
class |
SystemProcessingTimeService
A
TimerService which assigns as current processing time the result of calling System.currentTimeMillis() and registers timers using a ScheduledThreadPoolExecutor . |
class |
TimerException
RuntimeException for wrapping exceptions that are thrown in the timer callback of the
timer service in StreamTask . |
interface |
TimerService
A common timer service interface with life cycle methods.
|
class |
TwoInputStreamTask<IN1,IN2,OUT>
A
StreamTask for executing a TwoInputStreamOperator and supporting the TwoInputStreamOperator to select input for reading. |
Modifier and Type | Class and Description |
---|---|
class |
Mail
An executable bound to a specific operator in the chain, such that it can be picked for
downstream mailbox.
|
interface |
MailboxDefaultAction
Interface for the default action that is repeatedly invoked in the mailbox-loop.
|
static interface |
MailboxDefaultAction.Controller
This context is a feedback interface for the default action to interact with the mailbox
execution.
|
static interface |
MailboxDefaultAction.Suspension
Represents the suspended state of a
MailboxDefaultAction , ready to resume. |
interface |
MailboxExecutorFactory
A factory for creating mailbox executors with a given priority.
|
class |
MailboxExecutorImpl
Implementation of an executor service build around a mailbox-based execution model.
|
class |
MailboxProcessor
This class encapsulates the logic of the mailbox-based execution model.
|
interface |
TaskMailbox
A task mailbox provides read and write access to a mailbox and has a lifecycle of open ->
(quiesced) -> closed.
|
Modifier and Type | Class and Description |
---|---|
class |
StreamingFunctionUtils
Utility class that contains helper methods to work with Flink Streaming
Functions . |
Modifier and Type | Class and Description |
---|---|
class |
KeySelectorUtil
Utility class that contains helper methods to manipulating
KeySelector for streaming. |
Modifier and Type | Class and Description |
---|---|
class |
FieldAccessor<T,F>
These classes encapsulate the logic of accessing a field specified by the user as either an index
or a field expression string.
|
class |
FieldAccessorFactory
Static factories for the
FieldAccessor utilities. |
Modifier and Type | Method and Description |
---|---|
static <T,F> FieldAccessor<T,F> |
FieldAccessorFactory.getAccessor(TypeInformation<T> typeInfo,
int pos,
ExecutionConfig config)
Creates a
FieldAccessor for the given field position, which can be used to get and
set the specified field on instances of this type. |
static <T,F> FieldAccessor<T,F> |
FieldAccessorFactory.getAccessor(TypeInformation<T> typeInfo,
String field,
ExecutionConfig config)
Creates a
FieldAccessor for the field that is given by a field expression, which can
be used to get and set the specified field on instances of this type. |
Modifier and Type | Method and Description |
---|---|
Map<String,String> |
EnvironmentSettings.toExecutorProperties() |
Map<String,String> |
EnvironmentSettings.toPlannerProperties() |
Modifier and Type | Class and Description |
---|---|
class |
StreamTableEnvironmentImpl
The implementation for a Java
StreamTableEnvironment . |
Modifier and Type | Method and Description |
---|---|
StreamExecutionEnvironment |
StreamTableEnvironmentImpl.execEnv()
This is a temporary workaround for Python API.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CollectResultProvider
An internal class which helps the client to get the execute result from a specific sink.
|
interface |
Registration
A way to register a table in a
TableEnvironment that this descriptor originates from. |
class |
TableEnvironmentImpl
Implementation of
TableEnvironment that works exclusively with Table API interfaces. |
interface |
TableEnvironmentInternal
An internal interface of
TableEnvironment that defines extended methods used for TableImpl . |
class |
TableImpl
Implementation for
Table . |
class |
TableResultImpl
Implementation for
TableResult . |
Modifier and Type | Interface and Description |
---|---|
interface |
ExtendedRelTypeFactory
A factory for creating
RelDataType instances including Flink-specific extensions. |
class |
FlinkCalciteSqlValidator
Extends Calcite's
SqlValidator by Flink-specific behavior. |
Modifier and Type | Class and Description |
---|---|
class |
CatalogCalciteSchema
A mapping between Flink's catalog and Calcite's schema.
|
class |
CatalogManager
A manager for dealing with catalog objects such as tables, views, functions, and types.
|
class |
CatalogManagerCalciteSchema
Bridge between the
CatalogManager and the Schema . |
class |
CatalogPropertiesUtil
Utilities for de/serializing
Catalog objects into a map of string properties. |
class |
CatalogReader
A thin wrapper around
CalciteCatalogReader that enables providing multiple default paths
to look in. |
class |
CatalogTableImpl
Deprecated.
Use
CatalogTable.of(Schema, String, List, Map) or a custom implementation
instead. Don't implement against this internal class. It can lead to unintended side effects
if code checks against this class instead of the common interface. |
class |
CatalogViewImpl
Deprecated.
Use
CatalogView.of(Schema, String, String, String, Map) or a custom
implementation instead. Don't implement against this internal class. It can lead to
unintended side effects if code checks against this class instead of the common interface. |
class |
CommonCatalogOptions
A collection of
ConfigOption which are consistently used in multiple catalogs. |
class |
ConnectorCatalogTable<T1,T2>
|
class |
ExternalSchemaTranslator
Utility to derive a physical
DataType , Schema , and projections when entering or
leaving the table ecosystem from and to other APIs where TypeInformation is required. |
class |
FunctionCatalog
Simple function catalog to store
FunctionDefinition s in catalogs. |
class |
FunctionCatalogOperatorTable
Thin adapter between
SqlOperatorTable and FunctionCatalog . |
interface |
FunctionLookup
Catalog of functions that can resolve the name of a function to a
FunctionLookup.Result . |
class |
GenericInMemoryCatalogFactoryOptions
|
class |
QueryOperationCatalogView
A view created from a
QueryOperation via operations on Table . |
class |
QueryOperationCatalogViewTable
A bridge between a Flink's specific
QueryOperationCatalogView and a Calcite's Table . |
class |
UnresolvedIdentifier
Identifier of an object, such as table, view, function or type in a catalog.
|
Modifier and Type | Class and Description |
---|---|
class |
HiveMetastoreClientWrapper
Wrapper class for Hive Metastore Client, which embeds a HiveShim layer to handle different Hive
versions.
|
Modifier and Type | Class and Description |
---|---|
class |
HiveCatalogFactoryOptions
ConfigOption s for HiveCatalog . |
Modifier and Type | Class and Description |
---|---|
class |
HiveTypeUtil
Utils to convert data types between Flink and Hive.
|
Modifier and Type | Interface and Description |
---|---|
interface |
BulkDecodingFormat<T>
|
Modifier and Type | Class and Description |
---|---|
class |
BinaryArrayData
A binary implementation of
ArrayData which is backed by MemorySegment s. |
interface |
BinaryFormat
Binary format spanning
MemorySegment s. |
class |
BinaryMapData
[4 byte(keyArray size in bytes)] + [Key BinaryArray] + [Value BinaryArray].
|
class |
BinaryRawValueData<T>
A lazily binary implementation of
RawValueData which is backed by MemorySegment s
and generic Object . |
class |
BinaryRowData
An implementation of
RowData which is backed by MemorySegment instead of Object. |
class |
BinarySection
A basic implementation of
BinaryFormat which describe a section of memory. |
class |
BinarySegmentUtils
Utilities for binary data segments which heavily uses
MemorySegment . |
class |
BinaryStringData
|
class |
LazyBinaryFormat<T>
An abstract implementation fo
BinaryFormat which is lazily serialized into binary or
lazily deserialized into Java object. |
class |
NestedRowData
Its memory storage structure is exactly the same with
BinaryRowData . |
interface |
NullAwareGetters
Provides null related getters.
|
interface |
TypedSetters
Provide type specialized setters to reduce if/else and eliminate box and unbox.
|
Modifier and Type | Class and Description |
---|---|
class |
ArrayBooleanArrayConverter
Converter for
ArrayType of boolean[] external type. |
class |
ArrayByteArrayConverter
Converter for
ArrayType of byte[] external type. |
class |
ArrayDoubleArrayConverter
Converter for
ArrayType of double[] external type. |
class |
ArrayFloatArrayConverter
Converter for
ArrayType of float[] external type. |
class |
ArrayIntArrayConverter
Converter for
ArrayType of int[] external type. |
class |
ArrayListConverter<E>
|
class |
ArrayLongArrayConverter
Converter for
ArrayType of long[] external type. |
class |
ArrayObjectArrayConverter<E>
Converter for
ArrayType of nested primitive or object arrays external types. |
class |
ArrayShortArrayConverter
Converter for
ArrayType of short[] external type. |
interface |
DataStructureConverter<I,E>
Converter between internal and external data structure.
|
class |
DataStructureConverters
Registry of available data structure converters.
|
class |
DateDateConverter
|
class |
DateLocalDateConverter
Converter for
DateType of LocalDate external type. |
class |
DayTimeIntervalDurationConverter
Converter for
DayTimeIntervalType of Duration external type. |
class |
DecimalBigDecimalConverter
Converter for
DecimalType of BigDecimal external type. |
class |
IdentityConverter<I>
No-op converter that just forwards its input.
|
class |
LocalZonedTimestampInstantConverter
Converter for
LocalZonedTimestampType of Instant external type. |
class |
LocalZonedTimestampIntConverter
Converter for
LocalZonedTimestampType of Integer external type. |
class |
LocalZonedTimestampLongConverter
Converter for
LocalZonedTimestampType of Long external type. |
class |
LocalZonedTimestampTimestampConverter
Converter for
LocalZonedTimestampType of Timestamp external type. |
class |
MapMapConverter<K,V>
|
class |
RawByteArrayConverter<T>
Converter for
RawType of byte[] external type. |
class |
RawObjectConverter<T>
Converter for
RawType of object external type. |
class |
RowRowConverter
|
class |
StringByteArrayConverter
|
class |
StringStringConverter
|
class |
StructuredObjectConverter<T>
Converter for
StructuredType of its implementation class. |
class |
TimeLocalTimeConverter
Converter for
TimeType of LocalTime external type. |
class |
TimeLongConverter
|
class |
TimestampLocalDateTimeConverter
Converter for
TimestampType of LocalDateTime external type. |
class |
TimestampTimestampConverter
Converter for
TimestampType of Timestamp external type. |
class |
TimeTimeConverter
|
class |
YearMonthIntervalPeriodConverter
Converter for
YearMonthIntervalType of Period external type. |
Modifier and Type | Class and Description |
---|---|
class |
JoinedRowData
|
Modifier and Type | Class and Description |
---|---|
class |
BinaryArrayWriter
Writer for binary array.
|
class |
BinaryRowWriter
Writer for
BinaryRowData . |
interface |
BinaryWriter
Writer to write a composite data format, like row, array.
|