Modifier and Type | Class and Description |
---|---|
class |
CodeAnalysisMode
Specifies to which extent user-defined functions are analyzed in order
to give the Flink optimizer an insight of UDF internals and inform
the user about common implementation mistakes.
|
interface |
Program
A Program represents and end-to-end Flink program.
|
interface |
ProgramDescription
Implementing this interface allows a Program to have a description
of the plan which can be shown to the user.
|
Modifier and Type | Method and Description |
---|---|
long |
ExecutionConfig.getAutoWatermarkInterval()
Returns the interval of the automatic watermark emission.
|
CodeAnalysisMode |
ExecutionConfig.getCodeAnalysisMode()
Returns the
CodeAnalysisMode of the program. |
Integer |
JobExecutionResult.getIntCounterResult(String accumulatorName)
Deprecated.
Will be removed in future versions. Use
JobExecutionResult.getAccumulatorResult(java.lang.String) instead. |
long |
ExecutionConfig.getLatencyTrackingInterval()
Returns the latency tracking interval.
|
int |
ExecutionConfig.getMaxParallelism()
Gets the maximum degree of parallelism defined for the program.
|
RestartStrategies.RestartStrategyConfiguration |
ExecutionConfig.getRestartStrategy()
Returns the restart strategy which has been set for the current job.
|
long |
ExecutionConfig.getTaskCancellationTimeout()
Returns the timeout (in milliseconds) after which an ongoing task
cancellation leads to a fatal TaskManager error.
|
boolean |
ExecutionConfig.isLatencyTrackingEnabled()
Deprecated.
will be removed in a future version
|
ExecutionConfig |
ExecutionConfig.setAutoWatermarkInterval(long interval)
Sets the interval of the automatic watermark emission.
|
void |
ExecutionConfig.setCodeAnalysisMode(CodeAnalysisMode codeAnalysisMode)
Sets the
CodeAnalysisMode of the program. |
ExecutionConfig |
ExecutionConfig.setLatencyTrackingInterval(long interval)
Interval for sending latency tracking marks from the sources to the sinks.
|
void |
ExecutionConfig.setMaxParallelism(int maxParallelism)
Sets the maximum degree of parallelism defined for the program.
|
void |
ExecutionConfig.setRestartStrategy(RestartStrategies.RestartStrategyConfiguration restartStrategyConfiguration)
Sets the restart strategy to be used for recovery.
|
ExecutionConfig |
ExecutionConfig.setTaskCancellationTimeout(long timeout)
Sets the timeout (in milliseconds) after which an ongoing task cancellation
is considered failed, leading to a fatal TaskManager error.
|
Modifier and Type | Class and Description |
---|---|
class |
DoubleCounter
An accumulator that sums up
double values. |
class |
DoubleMaximum
An accumulator that finds the maximum
double value. |
class |
DoubleMinimum
An accumulator that finds the minimum
double value. |
class |
IntCounter
An accumulator that sums up
Integer values. |
class |
IntMaximum
An accumulator that finds the maximum
integer value. |
class |
IntMinimum
An accumulator that finds the minimum
integer value. |
class |
LongCounter
An accumulator that sums up
long values. |
class |
LongMaximum
An accumulator that finds the maximum
long value. |
class |
LongMinimum
An accumulator that finds the minimum
long value. |
class |
SerializedListAccumulator<T>
This accumulator stores a collection of objects in serialized form, so that the stored objects
are not affected by modifications to the original objects.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Aggregator<T extends Value>
Aggregators are a means of aggregating values across parallel instances of a function.
|
class |
AggregatorWithName<T extends Value>
Simple utility class holding an
Aggregator with the name it is registered under. |
interface |
ConvergenceCriterion<T extends Value>
Used to check for convergence.
|
class |
DoubleSumAggregator
An
Aggregator that sums up DoubleValue values. |
class |
DoubleZeroConvergence
A
ConvergenceCriterion over an Aggregator that defines convergence as reached once the aggregator
holds the value zero. |
class |
LongSumAggregator
An
Aggregator that sums up long values. |
class |
LongZeroConvergence
A
ConvergenceCriterion over an Aggregator that defines convergence as reached once the aggregator
holds the value zero. |
Modifier and Type | Interface and Description |
---|---|
interface |
DataDistribution |
interface |
RangeBoundaries<T>
RangeBoundaries is used to split the records into multiple ranges.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AggregateFunction<IN,ACC,OUT>
The
AggregateFunction is a flexible aggregation function, characterized by the
following features:
The aggregates may use different types for input values, intermediate aggregates,
and result type, to support a wide range of aggregation types.
Support for distributive aggregations: Different intermediate aggregates can be
merged together, to allow for pre-aggregation/final-aggregation optimizations.
|
class |
RichAggregateFunction<IN,ACC,OUT>
Rich variant of the
AggregateFunction . |
interface |
StoppableFunction
Must be implemented by stoppable functions, eg, source functions of streaming jobs.
|
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
RuntimeContext.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties)
Gets a handle to the system's key/value aggregating state.
|
Map<String,Accumulator<?,?>> |
RuntimeContext.getAllAccumulators()
Deprecated.
Use getAccumulator(..) to obtain the value of an accumulator.
|
DoubleCounter |
RuntimeContext.getDoubleCounter(String name)
Convenience function to create a counter object for doubles.
|
<T,ACC> FoldingState<T,ACC> |
RuntimeContext.getFoldingState(FoldingStateDescriptor<T,ACC> stateProperties)
Deprecated.
will be removed in a future version in favor of
AggregatingState |
Histogram |
RuntimeContext.getHistogram(String name)
Convenience function to create a counter object for histograms.
|
IntCounter |
RuntimeContext.getIntCounter(String name)
Convenience function to create a counter object for integers.
|
<T extends Aggregator<?>> |
IterationRuntimeContext.getIterationAggregator(String name) |
<T> ListState<T> |
RuntimeContext.getListState(ListStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value list state.
|
LongCounter |
RuntimeContext.getLongCounter(String name)
Convenience function to create a counter object for longs.
|
<UK,UV> MapState<UK,UV> |
RuntimeContext.getMapState(MapStateDescriptor<UK,UV> stateProperties)
Gets a handle to the system's key/value map state.
|
int |
RuntimeContext.getMaxNumberOfParallelSubtasks()
Gets the number of max-parallelism with which the parallel task runs.
|
MetricGroup |
RuntimeContext.getMetricGroup()
Returns the metric group for this parallel subtask.
|
<T> ReducingState<T> |
RuntimeContext.getReducingState(ReducingStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value reducing state.
|
<T> ValueState<T> |
RuntimeContext.getState(ValueStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value state.
|
boolean |
RuntimeContext.hasBroadcastVariable(String name)
Tests for the existence of the broadcast variable identified by the
given
name . |
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
AbstractRuntimeUDFContext.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties) |
<T,ACC> FoldingState<T,ACC> |
AbstractRuntimeUDFContext.getFoldingState(FoldingStateDescriptor<T,ACC> stateProperties)
Deprecated.
|
<T> ListState<T> |
AbstractRuntimeUDFContext.getListState(ListStateDescriptor<T> stateProperties) |
<UK,UV> MapState<UK,UV> |
AbstractRuntimeUDFContext.getMapState(MapStateDescriptor<UK,UV> stateProperties) |
<T> ReducingState<T> |
AbstractRuntimeUDFContext.getReducingState(ReducingStateDescriptor<T> stateProperties) |
<T> ValueState<T> |
AbstractRuntimeUDFContext.getState(ValueStateDescriptor<T> stateProperties) |
Modifier and Type | Interface and Description |
---|---|
interface |
CheckpointableInputFormat<S extends InputSplit,T extends Serializable>
An interface that describes
InputFormat s that allow checkpointing/restoring their state. |
class |
FilePathFilter
The
FilePathFilter.filterPath(Path) method is responsible for deciding if a path is eligible for further
processing or not. |
class |
ParseException
Exception indicating that the parsing of input contents has failed because the data
does not match the configured parser.
|
class |
ReplicatingInputFormat<OT,S extends InputSplit>
A ReplicatingInputFormat replicates any
InputFormat to all parallel instances of a DataSource,
i.e., the full input of the replicated InputFormat is completely processed by each parallel instance of the DataSource. |
Modifier and Type | Method and Description |
---|---|
void |
RichInputFormat.closeInputFormat()
Closes this InputFormat instance.
|
Charset |
DelimitedInputFormat.getCharset()
Get the character set used for the row delimiter.
|
Long |
DelimitedInputFormat.getCurrentState() |
Tuple2<Long,Long> |
BinaryInputFormat.getCurrentState() |
void |
RichInputFormat.openInputFormat()
Opens this InputFormat instance.
|
void |
DelimitedInputFormat.reopen(FileInputSplit split,
Long state) |
void |
BinaryInputFormat.reopen(FileInputSplit split,
Tuple2<Long,Long> state) |
void |
DelimitedInputFormat.setCharset(String charset)
Set the name of the character set used for the row delimiter.
|
Modifier and Type | Field and Description |
---|---|
static float |
BaseStatistics.AVG_RECORD_BYTES_UNKNOWN
Constant indicating that average record width is unknown.
|
static long |
BaseStatistics.NUM_RECORDS_UNKNOWN
Constant indicating that the number of records is unknown;
|
static long |
BaseStatistics.SIZE_UNKNOWN
Constant indicating that the input size is unknown.
|
Modifier and Type | Method and Description |
---|---|
float |
BaseStatistics.getAverageRecordWidth()
Gets the average width of a record, in bytes.
|
long |
BaseStatistics.getNumberOfRecords()
Gets the number of records in the input (= base cardinality).
|
long |
BaseStatistics.getTotalInputSize()
Gets the total size of the input.
|
Modifier and Type | Method and Description |
---|---|
ResourceSpec |
Operator.getMinResources()
Gets the minimum resources for this operator.
|
ResourceSpec |
Operator.getPreferredResources()
Gets the preferred resources for this contract instance.
|
void |
Operator.setResources(ResourceSpec minResources,
ResourceSpec preferredResources)
Sets the minimum and preferred resources for this contract instance.
|
Modifier and Type | Class and Description |
---|---|
class |
RestartStrategies
This class defines methods to generate RestartStrategyConfigurations.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractDeserializationSchema<T>
The deserialization schema describes how to turn the byte messages delivered by certain
data sources (for example Apache Kafka) into data types (Java/Scala objects) that are
processed by Flink.
|
class |
SimpleStringSchema
Very simple serialization schema for strings.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AggregatingState<IN,OUT>
State interface for aggregating state, based on an
AggregateFunction . |
class |
AggregatingStateDescriptor<IN,ACC,OUT>
A StateDescriptor for
AggregatingState . |
interface |
AppendingState<IN,OUT>
Base interface for partitioned state that supports adding elements and inspecting the current
state.
|
interface |
BroadcastState<K,V>
A type of state that can be created to store the state of a
BroadcastStream . |
interface |
FoldingState<T,ACC>
Deprecated.
will be removed in a future version in favor of
AggregatingState |
class |
FoldingStateDescriptor<T,ACC>
Deprecated.
will be removed in a future version in favor of
AggregatingStateDescriptor |
interface |
KeyedStateStore
This interface contains methods for registering keyed state with a managed store.
|
interface |
ListState<T>
State interface for partitioned list state in Operations. |
class |
ListStateDescriptor<T>
A
StateDescriptor for ListState . |
interface |
MapState<UK,UV>
State interface for partitioned key-value state. |
class |
MapStateDescriptor<UK,UV>
A
StateDescriptor for MapState . |
interface |
MergingState<IN,OUT>
Extension of
AppendingState that allows merging of state. |
interface |
OperatorStateStore
This interface contains methods for registering operator state with a managed store.
|
interface |
ReadOnlyBroadcastState<K,V>
A read-only view of the
BroadcastState . |
interface |
ReducingState<T>
State interface for reducing state. |
class |
ReducingStateDescriptor<T>
|
interface |
State
Interface that different types of partitioned state must implement.
|
class |
StateDescriptor<S extends State,T>
Base class for state descriptors.
|
interface |
ValueState<T>
State interface for partitioned single-value state. |
class |
ValueStateDescriptor<T>
|
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
KeyedStateStore.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties)
Gets a handle to the system's key/value folding state.
|
<T,ACC> FoldingState<T,ACC> |
KeyedStateStore.getFoldingState(FoldingStateDescriptor<T,ACC> stateProperties)
Deprecated.
will be removed in a future version in favor of
AggregatingState |
<T> ListState<T> |
KeyedStateStore.getListState(ListStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value list state.
|
<UK,UV> MapState<UK,UV> |
KeyedStateStore.getMapState(MapStateDescriptor<UK,UV> stateProperties)
Gets a handle to the system's key/value map state.
|
<T> ReducingState<T> |
KeyedStateStore.getReducingState(ReducingStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value reducing state.
|
<T> ValueState<T> |
KeyedStateStore.getState(ValueStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value state.
|
Modifier and Type | Class and Description |
---|---|
class |
Time
The definition of a time interval.
|
Modifier and Type | Class and Description |
---|---|
class |
SqlTimeTypeInfo<T>
Type information for Java SQL Date/Time/Timestamp.
|
class |
Types
This class gives access to the type information of the most common types for which Flink
has built-in serializers and comparators.
|
Modifier and Type | Method and Description |
---|---|
TypeComparator<T> |
BasicTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
PrimitiveArrayComparator<T,?> |
PrimitiveArrayTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
TypeSerializer<T> |
BasicArrayTypeInfo.createSerializer(ExecutionConfig executionConfig) |
abstract TypeSerializer<T> |
TypeInformation.createSerializer(ExecutionConfig config)
Creates a serializer for the type.
|
TypeSerializer<Nothing> |
NothingTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
BasicTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
PrimitiveArrayTypeInfo.createSerializer(ExecutionConfig executionConfig) |
int |
BasicArrayTypeInfo.getArity() |
abstract int |
TypeInformation.getArity()
Gets the arity of this type - the number of fields without nesting.
|
int |
NothingTypeInfo.getArity() |
int |
BasicTypeInfo.getArity() |
int |
PrimitiveArrayTypeInfo.getArity() |
Class<?> |
PrimitiveArrayTypeInfo.getComponentClass()
Gets the class that represents the component type.
|
TypeInformation<C> |
BasicArrayTypeInfo.getComponentInfo() |
TypeInformation<?> |
PrimitiveArrayTypeInfo.getComponentType()
Gets the type information of the component type.
|
Class<C> |
BasicArrayTypeInfo.getComponentTypeClass() |
Map<String,TypeInformation<?>> |
TypeInformation.getGenericParameters()
Optional method for giving Flink's type extraction system information about the mapping
of a generic type parameter to the type information of a subtype.
|
static <X> BasicTypeInfo<X> |
BasicTypeInfo.getInfoFor(Class<X> type) |
static <X> PrimitiveArrayTypeInfo<X> |
PrimitiveArrayTypeInfo.getInfoFor(Class<X> type)
Tries to get the PrimitiveArrayTypeInfo for an array.
|
static <X,C> BasicArrayTypeInfo<X,C> |
BasicArrayTypeInfo.getInfoFor(Class<X> type) |
int |
BasicArrayTypeInfo.getTotalFields() |
abstract int |
TypeInformation.getTotalFields()
Gets the number of logical fields in this type.
|
int |
NothingTypeInfo.getTotalFields() |
int |
BasicTypeInfo.getTotalFields() |
int |
PrimitiveArrayTypeInfo.getTotalFields() |
Class<T> |
BasicArrayTypeInfo.getTypeClass() |
abstract Class<T> |
TypeInformation.getTypeClass()
Gets the class of the type represented by this type information.
|
Class<Nothing> |
NothingTypeInfo.getTypeClass() |
Class<T> |
BasicTypeInfo.getTypeClass() |
Class<T> |
PrimitiveArrayTypeInfo.getTypeClass() |
boolean |
BasicArrayTypeInfo.isBasicType() |
abstract boolean |
TypeInformation.isBasicType()
Checks if this type information represents a basic type.
|
boolean |
NothingTypeInfo.isBasicType() |
boolean |
BasicTypeInfo.isBasicType() |
boolean |
PrimitiveArrayTypeInfo.isBasicType() |
boolean |
BasicArrayTypeInfo.isKeyType() |
abstract boolean |
TypeInformation.isKeyType()
Checks whether this type can be used as a key.
|
boolean |
NothingTypeInfo.isKeyType() |
boolean |
BasicTypeInfo.isKeyType() |
boolean |
PrimitiveArrayTypeInfo.isKeyType() |
boolean |
TypeInformation.isSortKeyType()
Checks whether this type can be used as a key for sorting.
|
boolean |
BasicArrayTypeInfo.isTupleType() |
abstract boolean |
TypeInformation.isTupleType()
Checks if this type information represents a Tuple type.
|
boolean |
NothingTypeInfo.isTupleType() |
boolean |
BasicTypeInfo.isTupleType() |
boolean |
PrimitiveArrayTypeInfo.isTupleType() |
boolean |
BasicTypeInfo.shouldAutocastTo(BasicTypeInfo<?> to)
Returns whether this type should be automatically casted to
the target type in an arithmetic operation.
|
Modifier and Type | Class and Description |
---|---|
class |
CompatibilityResult<T>
A
CompatibilityResult contains information about whether or not data migration
is required in order to continue using new serializers for previously serialized data. |
static class |
CompositeType.FlatFieldDescriptor |
static class |
CompositeType.InvalidFieldReferenceException |
protected static interface |
CompositeType.TypeComparatorBuilder<T> |
class |
CompositeTypeComparator<T> |
class |
TypeComparator<T>
This interface describes the methods that are required for a data type to be handled by the pact
runtime.
|
class |
TypeSerializer<T>
This interface describes the methods that are required for a data type to be handled by the Flink
runtime.
|
class |
TypeSerializerConfigSnapshot
A
TypeSerializerConfigSnapshot is a point-in-time view of a TypeSerializer's configuration. |
Modifier and Type | Method and Description |
---|---|
TypeComparator<T> |
CompositeType.createComparator(int[] logicalKeyFields,
boolean[] orders,
int logicalFieldOffset,
ExecutionConfig config)
Generic implementation of the comparator creation.
|
protected abstract CompositeType.TypeComparatorBuilder<T> |
CompositeType.createTypeComparatorBuilder() |
abstract int |
CompositeType.getFieldIndex(String fieldName)
Returns the field index of the composite field of the given name.
|
abstract String[] |
CompositeType.getFieldNames()
Returns the names of the composite fields of this type.
|
List<CompositeType.FlatFieldDescriptor> |
CompositeType.getFlatFields(String fieldExpression)
Returns the flat field descriptors for the given field expression.
|
abstract void |
CompositeType.getFlatFields(String fieldExpression,
int offset,
List<CompositeType.FlatFieldDescriptor> result)
Computes the flat field descriptors for the given field expression with the given offset.
|
abstract <X> TypeInformation<X> |
CompositeType.getTypeAt(int pos)
Returns the type of the (unnested) field at the given field position.
|
abstract <X> TypeInformation<X> |
CompositeType.getTypeAt(String fieldExpression)
Returns the type of the (nested) field at the given field expression position.
|
Class<T> |
CompositeType.getTypeClass()
Returns the type class of the composite type
|
boolean |
CompositeType.hasDeterministicFieldOrder()
True if this type has an inherent ordering of the fields, such that a user can
always be sure in which order the fields will be in.
|
boolean |
CompositeType.hasField(String fieldName)
Returns true when this type has a composite field with the given name.
|
boolean |
CompositeType.isKeyType() |
boolean |
CompositeType.isSortKeyType() |
Constructor and Description |
---|
CompositeType(Class<T> typeClass) |
Modifier and Type | Class and Description |
---|---|
class |
CollectionEnvironment
Version of
ExecutionEnvironment that allows serial, local, collection-based executions of Flink programs. |
Modifier and Type | Method and Description |
---|---|
static CollectionEnvironment |
ExecutionEnvironment.createCollectionsEnvironment()
Creates a
CollectionEnvironment that uses Java Collections underneath. |
static ExecutionEnvironment |
ExecutionEnvironment.createLocalEnvironmentWithWebUI(Configuration conf)
Creates a
LocalEnvironment for local program execution that also starts the
web monitoring UI. |
JobID |
ExecutionEnvironment.getId()
Gets the JobID by which this environment is identified.
|
String |
ExecutionEnvironment.getIdString()
Gets the JobID by which this environment is identified, as a string.
|
int |
ExecutionEnvironment.getNumberOfExecutionRetries()
Deprecated.
This method will be replaced by
ExecutionEnvironment.getRestartStrategy() . The
RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of
execution retries. |
RestartStrategies.RestartStrategyConfiguration |
ExecutionEnvironment.getRestartStrategy()
Returns the specified restart strategy configuration.
|
long |
ExecutionEnvironment.getSessionTimeout()
Gets the session timeout for this environment.
|
DataSink<T> |
DataSet.print(String sinkIdentifier)
Deprecated.
Use
DataSet.printOnTaskManager(String) instead. |
DataSink<T> |
DataSet.printToErr(String sinkIdentifier)
Deprecated.
Use
DataSet.printOnTaskManager(String) instead, or the PrintingOutputFormat . |
void |
ExecutionEnvironment.setNumberOfExecutionRetries(int numberOfExecutionRetries)
Deprecated.
This method will be replaced by
ExecutionEnvironment.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration) . The
RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of
execution retries. |
void |
ExecutionEnvironment.setRestartStrategy(RestartStrategies.RestartStrategyConfiguration restartStrategyConfiguration)
Sets the restart strategy configuration.
|
void |
ExecutionEnvironment.setSessionTimeout(long timeout)
Sets the session timeout to hold the intermediate results of a job.
|
void |
RemoteEnvironment.startNewSession() |
abstract void |
ExecutionEnvironment.startNewSession()
Starts a new session, discarding the previous data flow and all of its intermediate results.
|
void |
LocalEnvironment.startNewSession() |
Modifier and Type | Class and Description |
---|---|
class |
UnsupportedAggregationTypeException
Exception indicating an unsupported type was used for an aggregation.
|
Modifier and Type | Class and Description |
---|---|
class |
FlatMapIterator<IN,OUT>
A convenience variant of the
RichFlatMapFunction that returns elements through an iterator, rather then
through a collector. |
static interface |
FunctionAnnotation.ReadFields
The ReadFields annotation declares for a function all fields which it accesses and evaluates, i.e.,
all fields that are used by the function to compute its result.
|
static interface |
FunctionAnnotation.ReadFieldsFirst
The ReadFieldsFirst annotation declares for a function all fields of the first input which it accesses and evaluates, i.e.,
all fields of the first input that are used by the function to compute its result.
|
static interface |
FunctionAnnotation.ReadFieldsSecond
The ReadFieldsSecond annotation declares for a function all fields of the second input which it accesses and evaluates, i.e.,
all fields of the second input that are used by the function to compute its result.
|
static interface |
FunctionAnnotation.SkipCodeAnalysis
The SkipCodeAnalysis annotation declares that a function will not be analyzed by Flink's
code analysis capabilities independent of the configured
CodeAnalysisMode . |
class |
GroupReduceIterator<IN,OUT>
Base class that simplifies reducing all values provided as
Iterable . |
Modifier and Type | Class and Description |
---|---|
class |
HadoopDummyProgressable
This is a dummy progress.
|
class |
HadoopDummyReporter
This is a dummy progress monitor / reporter.
|
Modifier and Type | Class and Description |
---|---|
class |
CollectionInputFormat<T>
An input format that returns objects from a collection.
|
class |
CsvOutputFormat<T extends Tuple>
This is an OutputFormat to serialize
Tuple s to text. |
class |
IteratorInputFormat<T>
An input format that returns objects from an iterator.
|
class |
LocalCollectionOutputFormat<T>
An output format that adds records to a collection.
|
class |
ParallelIteratorInputFormat<T>
An input format that generates data in parallel through a
SplittableIterator . |
class |
PrimitiveInputFormat<OT>
An input format that reads single field primitive data from a given file.
|
class |
PrintingOutputFormat<T>
Output format that prints results into either stdout or stderr.
|
class |
RowCsvInputFormat
Input format that reads csv into
Row . |
class |
SplitDataProperties<T>
SplitDataProperties define data properties on
InputSplit
generated by the InputFormat of a DataSource . |
class |
TextInputFormat
Input Format that reads text files.
|
class |
TextOutputFormat<T>
A
FileOutputFormat that writes objects to a text file. |
class |
TextValueInputFormat
Input format that reads text files.
|
class |
TypeSerializerInputFormat<T>
Reads elements by deserializing them with a given type serializer.
|
class |
TypeSerializerOutputFormat<T>
Stores elements by serializing them with their type serializer.
|
Modifier and Type | Method and Description |
---|---|
CsvReader |
CsvReader.fieldDelimiter(char delimiter)
Deprecated.
Please use
CsvReader.fieldDelimiter(String) . |
String |
CsvReader.getCharset()
Gets the character set for the reader.
|
void |
CsvReader.setCharset(String charset)
Sets the charset of the reader.
|
Modifier and Type | Method and Description |
---|---|
AggregatorRegistry |
DeltaIteration.getAggregators()
Gets the registry for aggregators for the iteration.
|
AggregatorRegistry |
IterativeDataSet.getAggregators()
Gets the registry for aggregators.
|
ResourceSpec |
DeltaIteration.getMinResources()
Gets the minimum resources from this iteration.
|
ResourceSpec |
DataSink.getMinResources()
Returns the minimum resources of this data sink.
|
ResourceSpec |
DeltaIteration.getPreferredResources()
Gets the preferred resources from this iteration.
|
ResourceSpec |
DataSink.getPreferredResources()
Returns the preferred resources of this data sink.
|
SplitDataProperties<OUT> |
DataSource.getSplitDataProperties()
Returns the
SplitDataProperties for the
InputSplit s of this DataSource
for configurations. |
<X extends Value> |
DeltaIteration.registerAggregationConvergenceCriterion(String name,
Aggregator<X> aggregator,
ConvergenceCriterion<X> convergenceCheck)
Registers an
Aggregator for the iteration together with a ConvergenceCriterion . |
<X extends Value> |
IterativeDataSet.registerAggregationConvergenceCriterion(String name,
Aggregator<X> aggregator,
ConvergenceCriterion<X> convergenceCheck)
Registers an
Aggregator for the iteration together with a ConvergenceCriterion . |
DeltaIteration<ST,WT> |
DeltaIteration.registerAggregator(String name,
Aggregator<?> aggregator)
Registers an
Aggregator for the iteration. |
IterativeDataSet<T> |
IterativeDataSet.registerAggregator(String name,
Aggregator<?> aggregator)
Registers an
Aggregator for the iteration. |
O |
SingleInputUdfOperator.returns(String typeInfoString)
Deprecated.
Please use
SingleInputUdfOperator.returns(Class) or SingleInputUdfOperator.returns(TypeHint) instead. |
O |
TwoInputUdfOperator.returns(String typeInfoString)
Deprecated.
Please use
TwoInputUdfOperator.returns(Class) or TwoInputUdfOperator.returns(TypeHint) instead. |
ReduceOperator<IN> |
ReduceOperator.setCombineHint(ReduceOperatorBase.CombineHint strategy)
Sets the strategy to use for the combine phase of the reduce.
|
DistinctOperator<T> |
DistinctOperator.setCombineHint(ReduceOperatorBase.CombineHint strategy)
Sets the strategy to use for the combine phase of the reduce.
|
DataSink<T> |
DataSink.sortLocalOutput(int field,
Order order)
Deprecated.
Use
DataSet.sortPartition(int, Order) instead |
DataSink<T> |
DataSink.sortLocalOutput(String fieldExpression,
Order order)
Deprecated.
Use
DataSet.sortPartition(String, Order) instead |
<OUT extends Tuple> |
CrossOperator.ProjectCross.types(Class<?>... types)
Deprecated.
Deprecated method only kept for compatibility.
|
<OUT extends Tuple> |
JoinOperator.ProjectJoin.types(Class<?>... types)
Deprecated.
Deprecated method only kept for compatibility.
|
<R extends Tuple> |
ProjectOperator.types(Class<?>... types)
Deprecated.
Deprecated method only kept for compatibility.
|
PartitionOperator<T> |
PartitionOperator.withOrders(Order... orders)
Sets the order of keys for range partitioning.
|
Modifier and Type | Class and Description |
---|---|
class |
CodeAnalyzerException
Exception that is thrown if code analysis could not run properly.
|
class |
CodeErrorException
Exception that is thrown if code errors could be found during analysis.
|
Modifier and Type | Class and Description |
---|---|
class |
BooleanColumnSummary
Summary for a column of booleans.
|
class |
ColumnSummary
Summary for a column of values.
|
class |
NumericColumnSummary<T>
Generic Column Summary for Numeric Types.
|
class |
ObjectColumnSummary
Summary for a column of generic Objects (this is a fallback for unsupported types).
|
class |
StringColumnSummary
Summary for a column of Strings.
|
Modifier and Type | Class and Description |
---|---|
class |
ListTypeInfo<T>
A
TypeInformation for the list types of the Java API. |
class |
MapTypeInfo<K,V>
Special
TypeInformation used by MapStateDescriptor . |
class |
MultisetTypeInfo<T>
A
TypeInformation for the Multiset types of the Java API. |
class |
RowTypeInfo
TypeInformation for
Row |
Modifier and Type | Method and Description |
---|---|
TypeComparator<T> |
WritableTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
TypeComparator<T> |
ValueTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
TypeComparator<T> |
EnumTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
TypeComparator<T> |
GenericTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
TypeSerializer<T> |
WritableTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
ValueTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
EnumTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TupleSerializer<T> |
TupleTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
GenericTypeInfo.createSerializer(ExecutionConfig config) |
TypeSerializer<Either<L,R>> |
EitherTypeInfo.createSerializer(ExecutionConfig config) |
TypeSerializer<T> |
ObjectArrayTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
PojoTypeInfo.createSerializer(ExecutionConfig config) |
protected CompositeType.TypeComparatorBuilder<T> |
PojoTypeInfo.createTypeComparatorBuilder() |
static <IN1,IN2,OUT> |
TypeExtractor.createTypeInfo(Class<?> baseClass,
Class<?> clazz,
int returnParamPos,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <OUT> TypeInformation<OUT> |
TypeExtractor.createTypeInfo(Object instance,
Class<?> baseClass,
Class<?> clazz,
int returnParamPos)
Creates a
TypeInformation from the given parameters. |
static <IN,ACC> TypeInformation<ACC> |
TypeExtractor.getAggregateFunctionAccumulatorType(AggregateFunction<IN,ACC,?> function,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getAggregateFunctionReturnType(AggregateFunction<IN,?,OUT> function,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static List<Field> |
TypeExtractor.getAllDeclaredFields(Class<?> clazz,
boolean ignoreDuplicates)
Recursively determine all declared fields
This is required because class.getFields() is not returning fields defined
in parent classes.
|
int |
WritableTypeInfo.getArity() |
int |
ValueTypeInfo.getArity() |
int |
EnumTypeInfo.getArity() |
int |
GenericTypeInfo.getArity() |
int |
EitherTypeInfo.getArity() |
int |
ObjectArrayTypeInfo.getArity() |
int |
PojoTypeInfo.getArity() |
static <X extends Tuple> |
TupleTypeInfo.getBasicAndBasicValueTupleTypeInfo(Class<?>... basicTypes) |
static <X extends Tuple> |
TupleTypeInfo.getBasicTupleTypeInfo(Class<?>... basicTypes) |
static <IN1,IN2,OUT> |
TypeExtractor.getBinaryOperatorReturnType(Function function,
Class<?> baseClass,
int input1TypeArgumentIndex,
int input2TypeArgumentIndex,
int outputTypeArgumentIndex,
int[] lambdaInput1TypeArgumentIndices,
int[] lambdaInput2TypeArgumentIndices,
int[] lambdaOutputTypeArgumentIndices,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing)
Returns the binary operator's return type.
|
static <IN1,IN2,OUT> |
TypeExtractor.getCoGroupReturnTypes(CoGroupFunction<IN1,IN2,OUT> coGroupInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getCoGroupReturnTypes(CoGroupFunction<IN1,IN2,OUT> coGroupInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
TypeInformation<C> |
ObjectArrayTypeInfo.getComponentInfo() |
static <IN1,IN2,OUT> |
TypeExtractor.getCrossReturnTypes(CrossFunction<IN1,IN2,OUT> crossInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getCrossReturnTypes(CrossFunction<IN1,IN2,OUT> crossInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static Field |
TypeExtractor.getDeclaredField(Class<?> clazz,
String name) |
int |
TupleTypeInfo.getFieldIndex(String fieldName) |
int |
PojoTypeInfo.getFieldIndex(String fieldName) |
String[] |
TupleTypeInfo.getFieldNames() |
String[] |
PojoTypeInfo.getFieldNames() |
void |
PojoTypeInfo.getFlatFields(String fieldExpression,
int offset,
List<CompositeType.FlatFieldDescriptor> result) |
static <IN1,IN2,OUT> |
TypeExtractor.getFlatJoinReturnTypes(FlatJoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getFlatJoinReturnTypes(FlatJoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getFlatMapReturnTypes(FlatMapFunction<IN,OUT> flatMapInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getFlatMapReturnTypes(FlatMapFunction<IN,OUT> flatMapInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getFoldReturnTypes(FoldFunction<IN,OUT> foldInterface,
TypeInformation<IN> inType)
Deprecated.
will be removed in a future version
|
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getFoldReturnTypes(FoldFunction<IN,OUT> foldInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing)
Deprecated.
will be removed in a future version
|
Map<String,TypeInformation<?>> |
EitherTypeInfo.getGenericParameters() |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupCombineReturnTypes(GroupCombineFunction<IN,OUT> combineInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupCombineReturnTypes(GroupCombineFunction<IN,OUT> combineInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupReduceReturnTypes(GroupReduceFunction<IN,OUT> groupReduceInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupReduceReturnTypes(GroupReduceFunction<IN,OUT> groupReduceInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <T,C> ObjectArrayTypeInfo<T,C> |
ObjectArrayTypeInfo.getInfoFor(Class<T> arrayClass,
TypeInformation<C> componentInfo) |
static <C> MultisetTypeInfo<C> |
MultisetTypeInfo.getInfoFor(TypeInformation<C> componentInfo) |
static <T,C> ObjectArrayTypeInfo<T,C> |
ObjectArrayTypeInfo.getInfoFor(TypeInformation<C> componentInfo)
Creates a new
ObjectArrayTypeInfo from a
TypeInformation for the component type. |
static <IN> TypeInformation<IN> |
TypeExtractor.getInputFormatTypes(InputFormat<IN,?> inputFormatInterface) |
static <IN1,IN2,OUT> |
TypeExtractor.getJoinReturnTypes(JoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getJoinReturnTypes(JoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getKeySelectorTypes(KeySelector<IN,OUT> selectorInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getKeySelectorTypes(KeySelector<IN,OUT> selectorInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapPartitionReturnTypes(MapPartitionFunction<IN,OUT> mapPartitionInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapPartitionReturnTypes(MapPartitionFunction<IN,OUT> mapPartitionInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapReturnTypes(MapFunction<IN,OUT> mapInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapReturnTypes(MapFunction<IN,OUT> mapInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static Type |
TypeExtractor.getParameterType(Class<?> baseClass,
Class<?> clazz,
int pos) |
static <T> TypeInformation<T> |
TypeExtractor.getPartitionerTypes(Partitioner<T> partitioner) |
static <T> TypeInformation<T> |
TypeExtractor.getPartitionerTypes(Partitioner<T> partitioner,
String functionName,
boolean allowMissing) |
PojoField |
PojoTypeInfo.getPojoFieldAt(int pos) |
int |
WritableTypeInfo.getTotalFields() |
int |
ValueTypeInfo.getTotalFields() |
int |
EnumTypeInfo.getTotalFields() |
int |
GenericTypeInfo.getTotalFields() |
int |
EitherTypeInfo.getTotalFields() |
int |
ObjectArrayTypeInfo.getTotalFields() |
int |
PojoTypeInfo.getTotalFields() |
<X> TypeInformation<X> |
PojoTypeInfo.getTypeAt(int pos) |
<X> TypeInformation<X> |
PojoTypeInfo.getTypeAt(String fieldExpression) |
Class<T> |
WritableTypeInfo.getTypeClass() |
Class<T> |
ValueTypeInfo.getTypeClass() |
Class<T> |
EnumTypeInfo.getTypeClass() |
Class<T> |
GenericTypeInfo.getTypeClass() |
Class<Either<L,R>> |
EitherTypeInfo.getTypeClass() |
Class<T> |
ObjectArrayTypeInfo.getTypeClass() |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getUnaryOperatorReturnType(Function function,
Class<?> baseClass,
int inputTypeArgumentIndex,
int outputTypeArgumentIndex,
int[] lambdaInputTypeArgumentIndices,
int[] lambdaOutputTypeArgumentIndices,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing)
Returns the unary operator's return type.
|
boolean |
WritableTypeInfo.isBasicType() |
boolean |
ValueTypeInfo.isBasicType() |
boolean |
EnumTypeInfo.isBasicType() |
boolean |
GenericTypeInfo.isBasicType() |
boolean |
EitherTypeInfo.isBasicType() |
boolean |
ObjectArrayTypeInfo.isBasicType() |
boolean |
PojoTypeInfo.isBasicType() |
boolean |
ValueTypeInfo.isBasicValueType() |
boolean |
WritableTypeInfo.isKeyType() |
boolean |
ValueTypeInfo.isKeyType() |
boolean |
EnumTypeInfo.isKeyType() |
boolean |
GenericTypeInfo.isKeyType() |
boolean |
EitherTypeInfo.isKeyType() |
boolean |
ObjectArrayTypeInfo.isKeyType() |
boolean |
PojoTypeInfo.isSortKeyType() |
boolean |
WritableTypeInfo.isTupleType() |
boolean |
ValueTypeInfo.isTupleType() |
boolean |
EnumTypeInfo.isTupleType() |
boolean |
GenericTypeInfo.isTupleType() |
boolean |
EitherTypeInfo.isTupleType() |
boolean |
ObjectArrayTypeInfo.isTupleType() |
boolean |
PojoTypeInfo.isTupleType() |
Constructor and Description |
---|
EitherTypeInfo(TypeInformation<L> leftType,
TypeInformation<R> rightType) |
EnumTypeInfo(Class<T> typeClass) |
GenericTypeInfo(Class<T> typeClass) |
PojoTypeInfo(Class<T> typeClass,
List<PojoField> fields) |
TupleTypeInfo(Class<T> tupleType,
TypeInformation<?>... types) |
TupleTypeInfo(TypeInformation<?>... types) |
ValueTypeInfo(Class<T> type) |
WritableTypeInfo(Class<T> typeClass) |
Modifier and Type | Class and Description |
---|---|
class |
DataSetUtils
This class provides simple utility methods for zipping elements in a data set with an index
or with a unique identifier.
|
class |
Option
Internal representation of a parameter passed to a user defined function.
|
class |
OptionType
Types the parameters of managed with
RequiredParameters can take. |
class |
RequiredParameters
Facility to manage required parameters in user defined functions.
|
class |
RequiredParametersException
Exception which is thrown if validation of
RequiredParameters fails. |
Modifier and Type | Method and Description |
---|---|
Set<String> |
ParameterTool.getUnrequestedParameters()
Returns the set of parameter names which have not been requested with
ParameterTool.has(String) or one of the get methods. |
Modifier and Type | Class and Description |
---|---|
class |
ScalaCsvOutputFormat<T extends scala.Product>
This is an OutputFormat to serialize Scala Tuples to text.
|
Modifier and Type | Class and Description |
---|---|
class |
AkkaOptions
Akka configuration options.
|
class |
BlobServerOptions
Configuration options for the BlobServer and BlobCache.
|
class |
ConfigOption<T>
A
ConfigOption describes a configuration parameter. |
class |
ConfigOptions
ConfigOptions are used to build a ConfigOption . |
class |
CoreOptions
The set of configuration options for core parameters.
|
class |
HeartbeatManagerOptions
The set of configuration options relating to heartbeat manager settings.
|
class |
HighAvailabilityOptions
The set of configuration options relating to high-availability settings.
|
class |
HistoryServerOptions
The set of configuration options relating to the HistoryServer.
|
class |
IllegalConfigurationException
An
IllegalConfigurationException is thrown when
the values in a given Configuration are not valid. |
class |
JobManagerOptions
Configuration options for the JobManager.
|
class |
MemorySize
MemorySize is a representation of a number of bytes, viewable in different units.
|
class |
MetricOptions
Configuration options for metrics and metric reporters.
|
class |
OptimizerOptions
Configuration options for the optimizer.
|
class |
QueryableStateOptions
The set of configuration options relating to Queryable State.
|
class |
ResourceManagerOptions
The set of configuration options relating to the ResourceManager.
|
class |
SecurityOptions
The set of configuration options relating to security.
|
class |
TaskManagerOptions
The set of configuration options relating to TaskManager and Task settings.
|
class |
WebOptions
Configuration options for the WebRuntimeMonitor.
|
Modifier and Type | Field and Description |
---|---|
static String |
ConfigConstants.CHECKPOINTS_DIRECTORY_KEY
Deprecated.
Use
CheckpointingOptions.CHECKPOINTS_DIRECTORY instead. |
static String |
ConfigConstants.DEFAULT_HA_JOB_MANAGER_PORT
Deprecated.
No longer used.
|
static String |
ConfigConstants.DEFAULT_HA_MODE
Deprecated.
Deprecated in favour of
HighAvailabilityOptions.HA_MODE |
static String |
ConfigConstants.EXECUTION_RETRIES_KEY
Deprecated.
The configuration value will be replaced by
ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS
and the corresponding FixedDelayRestartStrategy. |
static String |
ConfigConstants.EXECUTION_RETRY_DELAY_KEY
Deprecated.
The configuration value will be replaced by
ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_DELAY
and the corresponding FixedDelayRestartStrategy. |
static String |
ConfigConstants.HA_JOB_DELAY
Deprecated.
Deprecated in favour of
HighAvailabilityOptions.HA_JOB_DELAY . |
static String |
ConfigConstants.HA_JOB_MANAGER_PORT
Ports used by the job manager if not in 'none' recovery mode.
|
static String |
ConfigConstants.HA_MODE
Deprecated.
Deprecated in favour of
HighAvailabilityOptions.HA_MODE |
static String |
ConfigConstants.HA_ZOOKEEPER_CHECKPOINT_COUNTER_PATH
Deprecated.
|
static String |
ConfigConstants.HA_ZOOKEEPER_CHECKPOINTS_PATH
Deprecated.
|
static String |
ConfigConstants.HA_ZOOKEEPER_CLIENT_ACL
Deprecated.
in favor of
HighAvailabilityOptions.ZOOKEEPER_CLIENT_ACL . |
static String |
ConfigConstants.HA_ZOOKEEPER_CONNECTION_TIMEOUT
Deprecated.
in favor of
HighAvailabilityOptions.ZOOKEEPER_CONNECTION_TIMEOUT . |
static String |
ConfigConstants.HA_ZOOKEEPER_DIR_KEY
Deprecated.
in favor of
HighAvailabilityOptions.HA_ZOOKEEPER_ROOT . |
static String |
ConfigConstants.HA_ZOOKEEPER_JOBGRAPHS_PATH
Deprecated.
in favor of
HighAvailabilityOptions.HA_ZOOKEEPER_JOBGRAPHS_PATH . |
static String |
ConfigConstants.HA_ZOOKEEPER_LATCH_PATH
Deprecated.
in favor of
HighAvailabilityOptions.HA_ZOOKEEPER_LATCH_PATH . |
static String |
ConfigConstants.HA_ZOOKEEPER_LEADER_PATH
Deprecated.
in favor of
HighAvailabilityOptions.HA_ZOOKEEPER_LEADER_PATH . |
static String |
ConfigConstants.HA_ZOOKEEPER_MAX_RETRY_ATTEMPTS
Deprecated.
in favor of
HighAvailabilityOptions.ZOOKEEPER_MAX_RETRY_ATTEMPTS . |
static ConfigOption<String> |
HighAvailabilityOptions.HA_ZOOKEEPER_MESOS_WORKERS_PATH
ZooKeeper root path (ZNode) for Mesos workers.
|
static String |
ConfigConstants.HA_ZOOKEEPER_MESOS_WORKERS_PATH
Deprecated.
|
static String |
ConfigConstants.HA_ZOOKEEPER_NAMESPACE_KEY
Deprecated.
in favor of
HighAvailabilityOptions.HA_CLUSTER_ID . |
static String |
ConfigConstants.HA_ZOOKEEPER_QUORUM_KEY
Deprecated.
in favor of
HighAvailabilityOptions.HA_ZOOKEEPER_QUORUM . |
static String |
ConfigConstants.HA_ZOOKEEPER_RETRY_WAIT
Deprecated.
in favor of
HighAvailabilityOptions.ZOOKEEPER_RETRY_WAIT |
static String |
ConfigConstants.HA_ZOOKEEPER_SESSION_TIMEOUT
Deprecated.
in favor of
HighAvailabilityOptions.ZOOKEEPER_SESSION_TIMEOUT . |
static String |
ConfigConstants.HA_ZOOKEEPER_STORAGE_PATH
Deprecated.
in favor of
HighAvailabilityOptions.HA_STORAGE_PATH . |
static String |
ConfigConstants.RESTART_STRATEGY
Defines the restart strategy to be used.
|
static String |
ConfigConstants.RESTART_STRATEGY_FAILURE_RATE_DELAY
Delay between two consecutive restart attempts in FailureRateRestartStrategy.
|
static String |
ConfigConstants.RESTART_STRATEGY_FAILURE_RATE_FAILURE_RATE_INTERVAL
Time interval in which greater amount of failures than
ConfigConstants.RESTART_STRATEGY_FAILURE_RATE_MAX_FAILURES_PER_INTERVAL causes
job fail in FailureRateRestartStrategy. |
static String |
ConfigConstants.RESTART_STRATEGY_FAILURE_RATE_MAX_FAILURES_PER_INTERVAL
Maximum number of restarts in given time interval
ConfigConstants.RESTART_STRATEGY_FAILURE_RATE_FAILURE_RATE_INTERVAL before failing a job
in FailureRateRestartStrategy. |
static String |
ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS
Maximum number of attempts the fixed delay restart strategy will try before failing a job.
|
static ConfigOption<String> |
ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_DELAY
Delay between two consecutive restart attempts in FixedDelayRestartStrategy.
|
static String |
ConfigConstants.SAVEPOINT_DIRECTORY_KEY
Deprecated.
Use
CheckpointingOptions.SAVEPOINT_DIRECTORY instead. |
static String |
ConfigConstants.TASK_CANCELLATION_INTERVAL_MILLIS
Deprecated.
Deprecated. Please use
TaskManagerOptions.TASK_CANCELLATION_INTERVAL . |
static String |
ConfigConstants.ZOOKEEPER_SASL_DISABLE
Deprecated.
in favor of
SecurityOptions.ZOOKEEPER_SASL_DISABLE . |
static String |
ConfigConstants.ZOOKEEPER_SASL_SERVICE_NAME
Deprecated.
in favor of
SecurityOptions.ZOOKEEPER_SASL_SERVICE_NAME . |
Modifier and Type | Method and Description |
---|---|
boolean |
Configuration.contains(ConfigOption<?> configOption)
Checks whether there is an entry for the given config option.
|
boolean |
Configuration.getBoolean(ConfigOption<Boolean> configOption)
Returns the value associated with the given config option as a boolean.
|
boolean |
Configuration.getBoolean(ConfigOption<Boolean> configOption,
boolean overrideDefault)
Returns the value associated with the given config option as a boolean.
|
double |
Configuration.getDouble(ConfigOption<Double> configOption)
Returns the value associated with the given config option as a
double . |
double |
Configuration.getDouble(ConfigOption<Double> configOption,
double overrideDefault)
Returns the value associated with the given config option as a
double . |
float |
Configuration.getFloat(ConfigOption<Float> configOption)
Returns the value associated with the given config option as a float.
|
float |
Configuration.getFloat(ConfigOption<Float> configOption,
float overrideDefault)
Returns the value associated with the given config option as a float.
|
int |
Configuration.getInteger(ConfigOption<Integer> configOption)
Returns the value associated with the given config option as an integer.
|
int |
Configuration.getInteger(ConfigOption<Integer> configOption,
int overrideDefault)
Returns the value associated with the given config option as an integer.
|
long |
Configuration.getLong(ConfigOption<Long> configOption)
Returns the value associated with the given config option as a long integer.
|
long |
Configuration.getLong(ConfigOption<Long> configOption,
long overrideDefault)
Returns the value associated with the given config option as a long integer.
|
String |
Configuration.getString(ConfigOption<String> configOption)
Returns the value associated with the given config option as a string.
|
String |
Configuration.getString(ConfigOption<String> configOption,
String overrideDefault)
Returns the value associated with the given config option as a string.
|
String |
Configuration.getValue(ConfigOption<?> configOption)
Returns the value associated with the given config option as a string.
|
void |
Configuration.setBoolean(ConfigOption<Boolean> key,
boolean value)
Adds the given value to the configuration object.
|
void |
Configuration.setDouble(ConfigOption<Double> key,
double value)
Adds the given value to the configuration object.
|
void |
Configuration.setFloat(ConfigOption<Float> key,
float value)
Adds the given value to the configuration object.
|
void |
Configuration.setInteger(ConfigOption<Integer> key,
int value)
Adds the given value to the configuration object.
|
void |
Configuration.setLong(ConfigOption<Long> key,
long value)
Adds the given value to the configuration object.
|
void |
Configuration.setString(ConfigOption<String> key,
String value)
Adds the given value to the configuration object.
|
Modifier and Type | Interface and Description |
---|---|
interface |
FileSystemFactory
A factory to create file systems.
|
class |
FileSystemKind
An enumeration defining the kind and characteristics of a
FileSystem . |
Modifier and Type | Class and Description |
---|---|
class |
LocalFileSystemFactory
A factory for the
LocalFileSystem . |
Modifier and Type | Interface and Description |
---|---|
interface |
InputSplitAssigner
An input split assigner distributes the
InputSplit s among the instances on which a
data source exists. |
interface |
Versioned
This interface is implemented by classes that provide a version number.
|
class |
VersionMismatchException
This exception signals that incompatible versions have been found during serialization.
|
Modifier and Type | Class and Description |
---|---|
class |
DataInputViewStreamWrapper
Utility class that turns an
InputStream into a DataInputView . |
class |
DataOutputViewStreamWrapper
Utility class that turns an
OutputStream into a DataOutputView . |
interface |
SeekableDataInputView
Interface marking a
DataInputView as seekable. |
interface |
SeekableDataOutputView
Interface marking a
DataOutputView as seekable. |
Modifier and Type | Class and Description |
---|---|
class |
ScheduledDropwizardReporter
Base class for
MetricReporter that wraps a
Dropwizard Reporter . |
Modifier and Type | Class and Description |
---|---|
class |
JsonNodeDeserializationSchema
DeserializationSchema that deserializes a JSON String into an ObjectNode.
|
class |
JsonRowDeserializationSchema
Deserialization schema from JSON to Flink types.
|
class |
JsonRowSerializationSchema
Serialization schema that serializes an object of Flink types into a JSON bytes.
|
Modifier and Type | Class and Description |
---|---|
class |
GraphiteReporter
This class acts as a factory for the
GraphiteReporter and allows using it as a
Flink reporter. |
Modifier and Type | Class and Description |
---|---|
class |
PrometheusReporter
MetricReporter that exports Metrics via Prometheus. |
Modifier and Type | Class and Description |
---|---|
class |
StatsDReporter
Largely based on the StatsDReporter class by ReadyTalk.
|
Modifier and Type | Class and Description |
---|---|
class |
QueryableStateClient
Client for querying Flink's managed state.
|
Modifier and Type | Method and Description |
---|---|
<K,S extends State,V> |
QueryableStateClient.getKvState(JobID jobId,
String queryableStateName,
K key,
TypeHint<K> keyTypeHint,
StateDescriptor<S,V> stateDescriptor)
Returns a future holding the request result.
|
<K,S extends State,V> |
QueryableStateClient.getKvState(JobID jobId,
String queryableStateName,
K key,
TypeInformation<K> keyTypeInfo,
StateDescriptor<S,V> stateDescriptor)
Returns a future holding the request result.
|
Modifier and Type | Class and Description |
---|---|
class |
ImmutableAggregatingState<IN,OUT>
A read-only
AggregatingState that does not allow for modifications. |
class |
ImmutableFoldingState<IN,ACC>
Deprecated.
|
class |
ImmutableListState<V>
A read-only
ListState that does not allow for modifications. |
class |
ImmutableMapState<K,V>
A read-only
MapState that does not allow for modifications. |
class |
ImmutableReducingState<V>
A read-only
ReducingState that does not allow for modifications. |
class |
ImmutableValueState<V>
A read-only
ValueState that does not allow for modifications. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractStateBackend
An abstract base implementation of the
StateBackend interface. |
interface |
CheckpointListener
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
interface |
FunctionInitializationContext
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
|
interface |
FunctionSnapshotContext
This interface provides a context in which user functions that use managed state (i.e.
|
class |
KeyedStateCheckpointOutputStream
Checkpoint output stream that allows to write raw keyed state in a partitioned way, split into key-groups.
|
class |
KeyGroupStatePartitionStreamProvider
This class provides access to an input stream that contains state data for one key group and the key group id.
|
interface |
ManagedSnapshotContext
This interface provides a context in which operators that use managed state (i.e.
|
class |
OperatorStateCheckpointOutputStream
Checkpoint output stream that allows to write raw operator state in a partitioned way.
|
interface |
StateBackend
A State Backend defines how the state of a streaming application is stored and
checkpointed.
|
interface |
StateBackendFactory<T extends StateBackend>
A factory to create a specific state backend.
|
interface |
StateInitializationContext
This interface provides a context in which operators can initialize by registering to managed state (i.e.
|
class |
StatePartitionStreamProvider
This class provides access to input streams that contain data of one state partition of a partitionable state.
|
interface |
StateSnapshotContext
This interface provides a context in which operators that use managed (i.e.
|
Modifier and Type | Method and Description |
---|---|
boolean |
VoidNamespaceTypeInfo.canEqual(Object obj) |
TypeSerializer<VoidNamespace> |
VoidNamespaceTypeInfo.createSerializer(ExecutionConfig config) |
boolean |
VoidNamespaceTypeInfo.equals(Object obj) |
int |
VoidNamespaceTypeInfo.getArity() |
int |
VoidNamespaceTypeInfo.getTotalFields() |
Class<VoidNamespace> |
VoidNamespaceTypeInfo.getTypeClass() |
int |
VoidNamespaceTypeInfo.hashCode() |
boolean |
VoidNamespaceTypeInfo.isBasicType() |
boolean |
VoidNamespaceTypeInfo.isKeyType() |
boolean |
VoidNamespaceTypeInfo.isTupleType() |
String |
VoidNamespaceTypeInfo.toString() |
Modifier and Type | Class and Description |
---|---|
class |
AbstractFileStateBackend
A base class for all state backends that store their metadata (and data) in files.
|
class |
FsStateBackend
This state backend holds the working state in the memory (JVM heap) of the TaskManagers.
|
class |
FsStateBackendFactory
A factory that creates an
FsStateBackend from a configuration. |
Modifier and Type | Class and Description |
---|---|
class |
MemoryStateBackend
This state backend holds the working state in the memory (JVM heap) of the TaskManagers.
|
class |
MemoryStateBackendFactory
A factory that creates an
MemoryStateBackend from a configuration. |
Modifier and Type | Class and Description |
---|---|
class |
TimeCharacteristic
The time characteristic defines how the system determines time for time-dependent
order and operations that depend on time (such as time windows).
|
interface |
TimerService
Interface for working with time and timers.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CheckpointedFunction
This is the core interface for stateful transformation functions, meaning functions
that maintain state across individual stream records.
|
interface |
ExternallyInducedSource<T,CD>
Sources that implement this interface do not trigger checkpoints when receiving a
trigger message from the checkpoint coordinator, but when their input data/events
indicate that a checkpoint should be triggered.
|
interface |
ListCheckpointed<T extends Serializable>
This interface can be implemented by functions that want to store state in checkpoints.
|
interface |
WithMasterCheckpointHook<E>
This interface can be implemented by streaming functions that need to trigger a
"global action" on the master (in the checkpoint coordinator) as part of every
checkpoint and restore operation.
|
Modifier and Type | Interface and Description |
---|---|
interface |
OutputSelector<OUT>
Interface for defining an OutputSelector for a
SplitStream using
the SingleOutputStreamOperator.split(org.apache.flink.streaming.api.collector.selector.OutputSelector<T>) call. |
Modifier and Type | Class and Description |
---|---|
class |
AsyncDataStream
A helper class to apply
AsyncFunction to a data stream. |
class |
BroadcastConnectedStream<IN1,IN2>
A BroadcastConnectedStream represents the result of connecting a keyed or non-keyed stream,
with a
BroadcastStream with broadcast state(s) . |
class |
BroadcastStream<T>
A
BroadcastStream is a stream with broadcast state(s) . |
class |
IterativeStream<T>
The iterative data stream represents the start of an iteration in a
DataStream . |
class |
QueryableStateStream<K,V>
Queryable state stream instance.
|
class |
SplitStream<OUT>
The SplitStream represents an operator that has been split using an
OutputSelector . |
class |
StreamProjection<IN>
The result of
DataStream.project(int...) . |
Modifier and Type | Method and Description |
---|---|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,R> function)
Applies the given
AggregateFunction to each window. |
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,R> function)
Applies the given aggregation function to each window.
|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given
AggregateFunction to each window. |
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given aggregation function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
AllWindowFunction<V,R,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
AllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
ProcessAllWindowFunction<V,R,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessAllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
ProcessWindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessWindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
WindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
WindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
AllWindowedStream<T,W> |
AllWindowedStream.allowedLateness(Time lateness)
Sets the time by which elements are allowed to be late.
|
WindowedStream<T,K,W> |
WindowedStream.allowedLateness(Time lateness)
Sets the time by which elements are allowed to be late.
|
QueryableStateStream<KEY,T> |
KeyedStream.asQueryableState(String queryableStateName)
Publishes the keyed stream as queryable ValueState instance.
|
<ACC> QueryableStateStream<KEY,ACC> |
KeyedStream.asQueryableState(String queryableStateName,
FoldingStateDescriptor<T,ACC> stateDescriptor)
Deprecated.
will be removed in a future version
|
QueryableStateStream<KEY,T> |
KeyedStream.asQueryableState(String queryableStateName,
ReducingStateDescriptor<T> stateDescriptor)
Publishes the keyed stream as a queryable ReducingState instance.
|
QueryableStateStream<KEY,T> |
KeyedStream.asQueryableState(String queryableStateName,
ValueStateDescriptor<T> stateDescriptor)
Publishes the keyed stream as a queryable ValueState instance.
|
BroadcastStream<T> |
DataStream.broadcast(MapStateDescriptor<?,?>... broadcastStateDescriptors)
Sets the partitioning of the
DataStream so that the output elements
are broadcasted to every parallel instance of the next operation. |
<R> BroadcastConnectedStream<T,R> |
DataStream.connect(BroadcastStream<R> broadcastStream)
Creates a new
BroadcastConnectedStream by connecting the current
DataStream or KeyedStream with a BroadcastStream . |
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.disableChaining()
Turns off chaining for this operator so thread co-location will not be used as an
optimization.
|
DataStreamSink<T> |
DataStreamSink.disableChaining()
Turns off chaining for this operator so thread co-location will not be
used as an optimization.
|
CoGroupedStreams.WithWindow<T1,T2,KEY,W> |
CoGroupedStreams.WithWindow.evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> newEvictor)
Sets the
Evictor that should be used to evict elements from a window before
emission. |
JoinedStreams.WithWindow<T1,T2,KEY,W> |
JoinedStreams.WithWindow.evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> newEvictor)
Sets the
Evictor that should be used to evict elements from a window before emission. |
AllWindowedStream<T,W> |
AllWindowedStream.evictor(Evictor<? super T,? super W> evictor)
Sets the
Evictor that should be used to evict elements from a window before emission. |
WindowedStream<T,K,W> |
WindowedStream.evictor(Evictor<? super T,? super W> evictor)
Sets the
Evictor that should be used to evict elements from a window before emission. |
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
AllWindowFunction<ACC,R,W> function)
Deprecated.
|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
AllWindowFunction<ACC,R,W> function,
TypeInformation<ACC> foldAccumulatorType,
TypeInformation<R> resultType)
|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
ProcessAllWindowFunction<ACC,R,W> function)
Deprecated.
|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
ProcessAllWindowFunction<ACC,R,W> function,
TypeInformation<ACC> foldAccumulatorType,
TypeInformation<R> resultType)
|
<R,ACC> SingleOutputStreamOperator<R> |
WindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
ProcessWindowFunction<ACC,R,K,W> windowFunction)
Deprecated.
|
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
WindowFunction<ACC,R,K,W> function)
Deprecated.
|
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
WindowFunction<ACC,R,K,W> function,
TypeInformation<ACC> foldAccumulatorType,
TypeInformation<R> resultType)
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.forceNonParallel()
Sets the parallelism and maximum parallelism of this operator to one.
|
ResourceSpec |
DataStream.getMinResources()
Gets the minimum resources for this operator.
|
ResourceSpec |
DataStream.getPreferredResources()
Gets the preferred resources for this operator.
|
DataStream<T> |
DataStream.global()
Sets the partitioning of the
DataStream so that the output values
all go to the first instance of the next processing operator. |
IterativeStream<T> |
DataStream.iterate()
Initiates an iterative part of the program that feeds back data streams.
|
IterativeStream<T> |
DataStream.iterate(long maxWaitTimeMillis)
Initiates an iterative part of the program that feeds back data streams.
|
DataStreamSink<T> |
DataStream.print()
Writes a DataStream to the standard output stream (stdout).
|
DataStreamSink<T> |
DataStream.printToErr()
Writes a DataStream to the standard output stream (stderr).
|
<OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(BroadcastProcessFunction<IN1,IN2,OUT> function)
Assumes as inputs a
BroadcastStream and a non-keyed DataStream and applies the given
BroadcastProcessFunction on them, thereby creating a transformed output stream. |
<OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(BroadcastProcessFunction<IN1,IN2,OUT> function,
TypeInformation<OUT> outTypeInfo)
Assumes as inputs a
BroadcastStream and a non-keyed DataStream and applies the given
BroadcastProcessFunction on them, thereby creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.process(CoProcessFunction<IN1,IN2,R> coProcessFunction)
Applies the given
CoProcessFunction on the connected input streams,
thereby creating a transformed output stream. |
<KS,OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT> function)
Assumes as inputs a
BroadcastStream and a KeyedStream and applies the given
KeyedBroadcastProcessFunction on them, thereby creating a transformed output stream. |
<KS,OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT> function,
TypeInformation<OUT> outTypeInfo)
Assumes as inputs a
BroadcastStream and a KeyedStream and applies the given
KeyedBroadcastProcessFunction on them, thereby creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(KeyedProcessFunction<KEY,T,R> keyedProcessFunction)
Applies the given
KeyedProcessFunction on the input stream, thereby creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.process(ProcessAllWindowFunction<T,R,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.process(ProcessAllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
DataStream.process(ProcessFunction<T,R> processFunction)
Applies the given
ProcessFunction on the input stream, thereby
creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(ProcessFunction<T,R> processFunction)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.process(ProcessWindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R extends Tuple> |
DataStream.project(int... fieldIndexes)
Initiates a Project transformation on a
Tuple DataStream .Note: Only Tuple DataStreams can be projected. |
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessAllWindowFunction<T,R,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessAllWindowFunction<T,R,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)
Applies the given window function to each window.
|
DataStream<T> |
DataStream.rescale()
Sets the partitioning of the
DataStream so that the output elements
are distributed evenly to a subset of instances of the next operation in a round-robin
fashion. |
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.returns(String typeInfoString)
Deprecated.
Please use
SingleOutputStreamOperator.returns(Class) or SingleOutputStreamOperator.returns(TypeHint) instead. |
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.setMaxParallelism(int maxParallelism)
Sets the maximum parallelism of this operator.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.setUidHash(String uidHash)
Sets an user provided hash for this operator.
|
DataStreamSink<T> |
DataStreamSink.setUidHash(String uidHash)
Sets an user provided hash for this operator.
|
DataStream<T> |
DataStream.shuffle()
Sets the partitioning of the
DataStream so that the output elements
are shuffled uniformly randomly to the next operation. |
AllWindowedStream<T,W> |
AllWindowedStream.sideOutputLateData(OutputTag<T> outputTag)
Send late arriving data to the side output identified by the given
OutputTag . |
WindowedStream<T,K,W> |
WindowedStream.sideOutputLateData(OutputTag<T> outputTag)
Send late arriving data to the side output identified by the given
OutputTag . |
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.slotSharingGroup(String slotSharingGroup)
Sets the slot sharing group of this operation.
|
DataStreamSink<T> |
DataStreamSink.slotSharingGroup(String slotSharingGroup)
Sets the slot sharing group of this operation.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.startNewChain()
Starts a new task chain beginning at this operator.
|
<R> SingleOutputStreamOperator<R> |
DataStream.transform(String operatorName,
TypeInformation<R> outTypeInfo,
OneInputStreamOperator<T,R> operator)
Method for passing user defined operators along with the type
information that will transform the DataStream.
|
<R> SingleOutputStreamOperator<R> |
KeyedStream.transform(String operatorName,
TypeInformation<R> outTypeInfo,
OneInputStreamOperator<T,R> operator) |
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.transform(String functionName,
TypeInformation<R> outTypeInfo,
TwoInputStreamOperator<IN1,IN2,R> operator) |
CoGroupedStreams.WithWindow<T1,T2,KEY,W> |
CoGroupedStreams.WithWindow.trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> newTrigger)
Sets the
Trigger that should be used to trigger window emission. |
JoinedStreams.WithWindow<T1,T2,KEY,W> |
JoinedStreams.WithWindow.trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> newTrigger)
Sets the
Trigger that should be used to trigger window emission. |
AllWindowedStream<T,W> |
AllWindowedStream.trigger(Trigger<? super T,? super W> trigger)
Sets the
Trigger that should be used to trigger window emission. |
WindowedStream<T,K,W> |
WindowedStream.trigger(Trigger<? super T,? super W> trigger)
Sets the
Trigger that should be used to trigger window emission. |
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.uid(String uid)
Sets an ID for this operator.
|
DataStreamSink<T> |
DataStreamSink.uid(String uid)
Sets an ID for this operator.
|
<W extends Window> |
CoGroupedStreams.Where.EqualTo.window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> assigner)
Specifies the window on which the co-group operation works.
|
<W extends Window> |
JoinedStreams.Where.EqualTo.window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> assigner)
Specifies the window on which the join operation works.
|
<W extends Window> |
KeyedStream.window(WindowAssigner<? super T,W> assigner)
Windows this data stream to a
WindowedStream , which evaluates windows
over a key grouped stream. |
<W extends Window> |
DataStream.windowAll(WindowAssigner<? super T,W> assigner)
Windows this data stream to a
KeyedTriggerWindowDataStream , which evaluates windows
over a key grouped stream. |
<T> SingleOutputStreamOperator<T> |
CoGroupedStreams.WithWindow.with(CoGroupFunction<T1,T2,T> function)
Deprecated.
This method will be removed once the
CoGroupedStreams.WithWindow.apply(CoGroupFunction) method is fixed
in the next major version of Flink (2.0). |
<T> SingleOutputStreamOperator<T> |
CoGroupedStreams.WithWindow.with(CoGroupFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Deprecated.
This method will be removed once the
CoGroupedStreams.WithWindow.apply(CoGroupFunction, TypeInformation)
method is fixed in the next major version of Flink (2.0). |
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(FlatJoinFunction<T1,T2,T> function)
Deprecated.
This method will be removed once the
JoinedStreams.WithWindow.apply(FlatJoinFunction)
method is fixed in the next major version of Flink (2.0). |
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(FlatJoinFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Deprecated.
This method will be replaced by
JoinedStreams.WithWindow.apply(FlatJoinFunction, TypeInformation) in Flink 2.0.
So use the JoinedStreams.WithWindow.apply(FlatJoinFunction, TypeInformation) in the future. |
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(JoinFunction<T1,T2,T> function)
Deprecated.
This method will be removed once the
JoinedStreams.WithWindow.apply(JoinFunction) method is fixed
in the next major version of Flink (2.0). |
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(JoinFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Deprecated.
This method will be removed once the
JoinedStreams.WithWindow.apply(JoinFunction, TypeInformation)
method is fixed in the next major version of Flink (2.0). |
DataStreamSink<T> |
DataStream.writeAsCsv(String path)
Writes a DataStream to the file specified by the path parameter.
|
DataStreamSink<T> |
DataStream.writeAsCsv(String path,
FileSystem.WriteMode writeMode)
Writes a DataStream to the file specified by the path parameter.
|
<X extends Tuple> |
DataStream.writeAsCsv(String path,
FileSystem.WriteMode writeMode,
String rowDelimiter,
String fieldDelimiter)
Writes a DataStream to the file specified by the path parameter.
|
DataStreamSink<T> |
DataStream.writeAsText(String path)
Writes a DataStream to the file specified by path in text format.
|
DataStreamSink<T> |
DataStream.writeAsText(String path,
FileSystem.WriteMode writeMode)
Writes a DataStream to the file specified by path in text format.
|
DataStreamSink<T> |
DataStream.writeToSocket(String hostName,
int port,
SerializationSchema<T> schema)
Writes the DataStream to a socket as a byte array.
|
DataStreamSink<T> |
DataStream.writeUsingOutputFormat(OutputFormat<T> format)
Writes the dataStream into an output, described by an OutputFormat.
|
Constructor and Description |
---|
AllWindowedStream(DataStream<T> input,
WindowAssigner<? super T,W> windowAssigner) |
WindowedStream(KeyedStream<T,K> input,
WindowAssigner<? super T,W> windowAssigner) |
WithWindow(DataStream<T1> input1,
DataStream<T2> input2,
KeySelector<T1,KEY> keySelector1,
KeySelector<T2,KEY> keySelector2,
TypeInformation<KEY> keyType,
WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor) |
Modifier and Type | Class and Description |
---|---|
static class |
CheckpointConfig.ExternalizedCheckpointCleanup
Cleanup behaviour for externalized checkpoints when the job is cancelled.
|
class |
StreamContextEnvironment
Special
StreamExecutionEnvironment that will be used in cases where the CLI client or
testing utilities create a StreamExecutionEnvironment that should be used when
StreamExecutionEnvironment.getExecutionEnvironment() is called. |
interface |
StreamExecutionEnvironmentFactory
Factory class for stream execution environments.
|
class |
StreamPlanEnvironment
A special
StreamExecutionEnvironment that is used in the web frontend when generating
a user-inspectable graph of a streaming job. |
Modifier and Type | Method and Description |
---|---|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.createInput(InputFormat<OUT,?> inputFormat)
Generic method to create an input data stream with
InputFormat . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.createInput(InputFormat<OUT,?> inputFormat,
TypeInformation<OUT> typeInfo)
Generic method to create an input data stream with
InputFormat . |
static StreamExecutionEnvironment |
StreamExecutionEnvironment.createLocalEnvironmentWithWebUI(Configuration conf)
Creates a
LocalStreamEnvironment for local program execution that also starts the
web monitoring UI. |
StreamExecutionEnvironment |
StreamExecutionEnvironment.disableOperatorChaining()
Disables operator chaining for streaming operators.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.enableCheckpointing()
Deprecated.
Use
StreamExecutionEnvironment.enableCheckpointing(long) instead. |
StreamExecutionEnvironment |
StreamExecutionEnvironment.enableCheckpointing(long interval,
CheckpointingMode mode,
boolean force)
Deprecated.
Use
StreamExecutionEnvironment.enableCheckpointing(long, CheckpointingMode) instead.
Forcing checkpoints will be removed in the future. |
void |
CheckpointConfig.enableExternalizedCheckpoints(CheckpointConfig.ExternalizedCheckpointCleanup cleanupMode)
Enables checkpoints to be persisted externally.
|
static int |
StreamExecutionEnvironment.getDefaultLocalParallelism()
Gets the default parallelism that will be used for the local execution environment created by
StreamExecutionEnvironment.createLocalEnvironment() . |
CheckpointConfig.ExternalizedCheckpointCleanup |
CheckpointConfig.getExternalizedCheckpointCleanup()
Returns the cleanup behaviour for externalized checkpoints.
|
int |
StreamExecutionEnvironment.getNumberOfExecutionRetries()
Deprecated.
This method will be replaced by
StreamExecutionEnvironment.getRestartStrategy() . |
RestartStrategies.RestartStrategyConfiguration |
StreamExecutionEnvironment.getRestartStrategy()
Returns the specified restart strategy configuration.
|
StateBackend |
StreamExecutionEnvironment.getStateBackend()
Gets the state backend that defines how to store and checkpoint state.
|
TimeCharacteristic |
StreamExecutionEnvironment.getStreamTimeCharacteristic()
Gets the time characteristic.
|
boolean |
StreamExecutionEnvironment.isChainingEnabled()
Returns whether operator chaining is enabled.
|
boolean |
CheckpointConfig.isExternalizedCheckpointsEnabled()
Returns whether checkpoints should be persisted externally.
|
boolean |
CheckpointConfig.isForceCheckpointing()
Deprecated.
This will be removed once iterations properly participate in checkpointing.
|
boolean |
StreamExecutionEnvironment.isForceCheckpointing()
Deprecated.
Forcing checkpoints will be removed in future version.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.readFile(FileInputFormat<OUT> inputFormat,
String filePath,
FileProcessingMode watchType,
long interval)
Reads the contents of the user-specified
filePath based on the given FileInputFormat . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.readFile(FileInputFormat<OUT> inputFormat,
String filePath,
FileProcessingMode watchType,
long interval,
FilePathFilter filter)
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.readFile(FileInputFormat<OUT> inputFormat,
String filePath,
FileProcessingMode watchType,
long interval,
TypeInformation<OUT> typeInformation)
Reads the contents of the user-specified
filePath based on the given FileInputFormat . |
static void |
StreamExecutionEnvironment.setDefaultLocalParallelism(int parallelism)
Sets the default parallelism that will be used for the local execution
environment created by
StreamExecutionEnvironment.createLocalEnvironment() . |
void |
CheckpointConfig.setForceCheckpointing(boolean forceCheckpointing)
Deprecated.
This will be removed once iterations properly participate in checkpointing.
|
void |
StreamExecutionEnvironment.setNumberOfExecutionRetries(int numberOfExecutionRetries)
Deprecated.
This method will be replaced by
StreamExecutionEnvironment.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration) . The
RestartStrategies.fixedDelayRestart(int, Time) contains the number of
execution retries. |
void |
StreamExecutionEnvironment.setRestartStrategy(RestartStrategies.RestartStrategyConfiguration restartStrategyConfiguration)
Sets the restart strategy configuration.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setStateBackend(AbstractStateBackend backend)
Deprecated.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setStateBackend(StateBackend backend)
Sets the state backend that describes how to store and checkpoint operator state.
|
void |
StreamExecutionEnvironment.setStreamTimeCharacteristic(TimeCharacteristic characteristic)
Sets the time characteristic for all streams create from this environment, e.g., processing
time, event time, or ingestion time.
|
DataStreamSource<String> |
StreamExecutionEnvironment.socketTextStream(String hostname,
int port)
Creates a new data stream that contains the strings received infinitely from a socket.
|
DataStreamSource<String> |
StreamExecutionEnvironment.socketTextStream(String hostname,
int port,
String delimiter)
Creates a new data stream that contains the strings received infinitely from a socket.
|
DataStreamSource<String> |
StreamExecutionEnvironment.socketTextStream(String hostname,
int port,
String delimiter,
long maxRetry)
Creates a new data stream that contains the strings received infinitely from a socket.
|
Modifier and Type | Class and Description |
---|---|
class |
AscendingTimestampExtractor<T>
Deprecated.
Extend
AscendingTimestampExtractor instead. |
class |
KeyedProcessFunction<K,I,O>
A keyed function that processes elements of a stream.
|
class |
ProcessFunction<I,O>
A function that processes elements of a stream.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AsyncFunction<IN,OUT>
A function to trigger Async I/O operation.
|
interface |
ResultFuture<OUT>
ResultFuture collects data / error in user codes while processing async i/o. |
class |
RichAsyncFunction<IN,OUT>
Rich variant of the
AsyncFunction . |
Modifier and Type | Class and Description |
---|---|
class |
BaseBroadcastProcessFunction
The base class containing the functionality available to all broadcast process function.
|
class |
BroadcastProcessFunction<IN1,IN2,OUT>
A function to be applied to a
BroadcastConnectedStream that
connects BroadcastStream , i.e. |
class |
CoProcessFunction<IN1,IN2,OUT>
A function that processes elements of two streams and produces a single output one.
|
class |
KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT>
A function to be applied to a
BroadcastConnectedStream that
connects BroadcastStream , i.e. |
Modifier and Type | Class and Description |
---|---|
class |
OutputFormatSinkFunction<IN>
Deprecated.
Please use the
BucketingSink for writing to files from a streaming program. |
class |
PrintSinkFunction<IN>
Implementation of the SinkFunction writing every tuple to the standard
output or standard error stream.
|
class |
SocketClientSink<IN>
Socket client that acts as a streaming sink.
|
class |
TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT>
This is a recommended base class for all of the
SinkFunction that intend to implement exactly-once semantic. |
class |
WriteFormat<IN>
Deprecated.
Please use the
BucketingSink for writing to files from a streaming program. |
class |
WriteFormatAsCsv<IN>
Deprecated.
Please use the
BucketingSink for writing to files from a streaming program. |
class |
WriteFormatAsText<IN>
Deprecated.
Please use the
BucketingSink for writing to files from a streaming program. |
class |
WriteSinkFunction<IN>
Deprecated.
Please use the
BucketingSink for writing to files from a streaming program. |
class |
WriteSinkFunctionByMillis<IN>
Deprecated.
Please use the
BucketingSink for writing to files from a streaming program. |
Modifier and Type | Class and Description |
---|---|
class |
FileProcessingMode
The mode in which the
ContinuousFileMonitoringFunction operates. |
class |
FromElementsFunction<T>
A stream source function that returns a sequence of elements.
|
class |
FromIteratorFunction<T>
A
SourceFunction that reads elements from an Iterator and emits them. |
class |
FromSplittableIteratorFunction<T>
A
SourceFunction that reads elements from an SplittableIterator and emits them. |
class |
MessageAcknowledgingSourceBase<Type,UId>
Abstract base class for data sources that receive elements from a message queue and
acknowledge them back by IDs.
|
class |
MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId>
Abstract base class for data sources that receive elements from a message queue and
acknowledge them back by IDs.
|
class |
SocketTextStreamFunction
A source function that reads strings from a socket.
|
class |
StatefulSequenceSource
A stateful streaming source that emits each number from a given interval exactly once,
possibly in parallel.
|
Modifier and Type | Method and Description |
---|---|
void |
SourceFunction.SourceContext.collectWithTimestamp(T element,
long timestamp)
Emits one element from the source, and attaches the given timestamp.
|
void |
SourceFunction.SourceContext.emitWatermark(Watermark mark)
Emits the given
Watermark . |
void |
SourceFunction.SourceContext.markAsTemporarilyIdle()
Marks the source to be temporarily idle.
|
Modifier and Type | Class and Description |
---|---|
class |
AscendingTimestampExtractor<T>
A timestamp assigner and watermark generator for streams where timestamps are monotonously
ascending.
|
Modifier and Type | Class and Description |
---|---|
class |
ProcessAllWindowFunction<IN,OUT,W extends Window>
Base abstract class for functions that are evaluated over non-keyed windows using a context
for retrieving extra information.
|
class |
ProcessWindowFunction<IN,OUT,KEY,W extends Window>
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
class |
RichProcessAllWindowFunction<IN,OUT,W extends Window>
Deprecated.
use
ProcessAllWindowFunction instead |
class |
RichProcessWindowFunction<IN,OUT,KEY,W extends Window>
Deprecated.
use
ProcessWindowFunction instead |
Modifier and Type | Class and Description |
---|---|
class |
CosineDistance<DATA>
This delta function calculates the cosine distance between two given vectors.
|
interface |
DeltaFunction<DATA>
This interface allows the implementation of a function which calculates the
delta between two data points.
|
class |
EuclideanDistance<DATA>
This delta function calculates the euclidean distance between two given
points.
|
class |
ExtractionAwareDeltaFunction<DATA,TO>
Extend this abstract class to implement a delta function which is aware of
extracting the data on which the delta is calculated from a more complex data
structure.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamOperator<OUT>
Base class for all stream operators.
|
class |
AbstractUdfStreamOperator<OUT,F extends Function>
This is used as the base class for operators that have a user-defined
function.
|
class |
ChainingStrategy
Defines the chaining scheme for the operator.
|
interface |
OneInputStreamOperator<IN,OUT>
Interface for stream operators with one input.
|
interface |
Output<T>
A
StreamOperator is supplied with an object
of this interface that can be used to emit elements and other messages, such as barriers
and watermarks, from an operator. |
interface |
OutputTypeConfigurable<OUT>
Stream operators can implement this interface if they need access to the output type information
at
StreamGraph generation. |
interface |
StreamOperator<OUT>
Basic interface for stream operators.
|
interface |
TwoInputStreamOperator<IN1,IN2,OUT>
Interface for stream operators with two inputs.
|
Modifier and Type | Class and Description |
---|---|
class |
Watermark
A Watermark tells operators that no elements with a timestamp older or equal
to the watermark timestamp should arrive at the operator.
|
Modifier and Type | Class and Description |
---|---|
class |
DynamicEventTimeSessionWindows<T>
A
WindowAssigner that windows elements into sessions based on the timestamp of the
elements. |
class |
DynamicProcessingTimeSessionWindows<T>
A
WindowAssigner that windows elements into sessions based on the current processing
time. |
class |
GlobalWindows
A
WindowAssigner that assigns all elements to the same GlobalWindow . |
class |
MergingWindowAssigner<T,W extends Window>
A
WindowAssigner that can merge windows. |
interface |
SessionWindowTimeGapExtractor<T>
A
SessionWindowTimeGapExtractor extracts session time gaps for Dynamic Session Window Assigners. |
class |
SlidingAlignedProcessingTimeWindows
This is a special window assigner used to tell the system to use the
"Fast Aligned Processing Time Window Operator" for windowing.
|
class |
SlidingEventTimeWindows
A
WindowAssigner that windows elements into sliding windows based on the timestamp of the
elements. |
class |
SlidingTimeWindows
Deprecated.
Please use
SlidingEventTimeWindows . |
class |
TumblingEventTimeWindows
A
WindowAssigner that windows elements into windows based on the timestamp of the
elements. |
class |
TumblingTimeWindows
Deprecated.
Please use
TumblingEventTimeWindows . |
class |
WindowAssigner<T,W extends Window>
A
WindowAssigner assigns zero or more Windows to an element. |
Modifier and Type | Method and Description |
---|---|
static <T> DynamicProcessingTimeSessionWindows<T> |
ProcessingTimeSessionWindows.withDynamicGap(SessionWindowTimeGapExtractor<T> sessionWindowTimeGapExtractor)
Creates a new
SessionWindows WindowAssigner that assigns
elements to sessions based on the element timestamp. |
static <T> DynamicEventTimeSessionWindows<T> |
EventTimeSessionWindows.withDynamicGap(SessionWindowTimeGapExtractor<T> sessionWindowTimeGapExtractor)
Creates a new
SessionWindows WindowAssigner that assigns
elements to sessions based on the element timestamp. |
Modifier and Type | Class and Description |
---|---|
class |
CountEvictor<W extends Window>
An
Evictor that keeps up to a certain amount of elements. |
class |
DeltaEvictor<T,W extends Window>
An
Evictor that keeps elements based on a DeltaFunction and a threshold. |
interface |
Evictor<T,W extends Window>
An
Evictor can remove elements from a pane before/after the evaluation of WindowFunction
and after the window evaluation gets triggered by a
Trigger |
class |
TimeEvictor<W extends Window>
An
Evictor that keeps elements for a certain amount of time. |
Modifier and Type | Class and Description |
---|---|
class |
ContinuousEventTimeTrigger<W extends Window>
A
Trigger that continuously fires based on a given time interval. |
class |
ContinuousProcessingTimeTrigger<W extends Window>
A
Trigger that continuously fires based on a given time interval as measured by
the clock of the machine on which the job is running. |
class |
CountTrigger<W extends Window>
A
Trigger that fires once the count of elements in a pane reaches the given count. |
class |
DeltaTrigger<T,W extends Window>
A
Trigger that fires based on a DeltaFunction and a threshold. |
class |
EventTimeTrigger
A
Trigger that fires once the watermark passes the end of the window
to which a pane belongs. |
class |
ProcessingTimeTrigger
A
Trigger that fires once the current system time passes the end of the window
to which a pane belongs. |
class |
PurgingTrigger<T,W extends Window>
A trigger that can turn any
Trigger into a purging Trigger . |
class |
Trigger<T,W extends Window>
A
Trigger determines when a pane of a window should be evaluated to emit the
results for that part of the window. |
Modifier and Type | Class and Description |
---|---|
class |
GlobalWindow
The default window into which all data is placed (via
GlobalWindows ). |
class |
TimeWindow
|
class |
Window
A
Window is a grouping of elements into finite buckets. |
Modifier and Type | Method and Description |
---|---|
CassandraSink<IN> |
CassandraSink.setUidHash(String uidHash)
Sets an user provided hash for this operator.
|
CassandraSink<IN> |
CassandraSink.uid(String uid)
Sets an ID for this operator.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ActionRequestFailureHandler
An implementation of
ActionRequestFailureHandler is provided by the user to define how failed
ActionRequests should be handled, e.g. |
class |
ElasticsearchSink<T>
Elasticsearch 1.x sink that requests multiple
ActionRequests
against a cluster for each incoming element. |
interface |
ElasticsearchSinkFunction<T>
Creates multiple
ActionRequests from an element in a stream. |
interface |
RequestIndexer
Users add multiple
ActionRequests to a RequestIndexer to prepare
them for sending to an Elasticsearch cluster. |
Modifier and Type | Class and Description |
---|---|
class |
RetryRejectedExecutionFailureHandler
An
ActionRequestFailureHandler that re-adds requests that failed due to temporary
EsRejectedExecutionException s (which means that Elasticsearch node queues are currently full),
and fails for all other failures. |
Modifier and Type | Class and Description |
---|---|
class |
ElasticsearchSink<T>
Elasticsearch 2.x sink that requests multiple
ActionRequests
against a cluster for each incoming element. |
Modifier and Type | Class and Description |
---|---|
class |
ElasticsearchSink<T>
Elasticsearch 5.x sink that requests multiple
ActionRequests
against a cluster for each incoming element. |
Modifier and Type | Class and Description |
---|---|
class |
FlinkKafka011ErrorCode
Error codes used in
FlinkKafka011Exception . |
class |
FlinkKafka011Exception
Exception used by
FlinkKafkaProducer011 and FlinkKafkaConsumer011 . |
class |
FlinkKafkaConsumer010<T>
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.10.x.
|
class |
FlinkKafkaConsumer011<T>
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.11.x.
|
class |
FlinkKafkaConsumer08<T>
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.8.x.
|
class |
FlinkKafkaConsumer09<T>
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.9.x.
|
class |
FlinkKafkaProducer010<T>
Flink Sink to produce data into a Kafka topic.
|
class |
FlinkKafkaProducer011<IN>
Flink Sink to produce data into a Kafka topic.
|
class |
FlinkKafkaProducer08<IN>
Flink Sink to produce data into a Kafka topic.
|
class |
FlinkKafkaProducer09<IN>
Flink Sink to produce data into a Kafka topic.
|
class |
Kafka010AvroTableSource
Kafka
StreamTableSource for Kafka 0.10. |
class |
Kafka010JsonTableSink
Kafka 0.10
KafkaTableSink that serializes data in JSON format. |
class |
Kafka010JsonTableSource
Kafka
StreamTableSource for Kafka 0.10. |
class |
Kafka010TableSource
Kafka
StreamTableSource for Kafka 0.10. |
class |
Kafka011AvroTableSource
Kafka
StreamTableSource for Kafka 0.11. |
class |
Kafka011JsonTableSource
Kafka
StreamTableSource for Kafka 0.11. |
class |
Kafka011TableSource
Kafka
StreamTableSource for Kafka 0.11. |
class |
Kafka08AvroTableSource
Kafka
StreamTableSource for Kafka 0.8. |
class |
Kafka08JsonTableSink
Kafka 0.8
KafkaTableSink that serializes data in JSON format. |
class |
Kafka08JsonTableSource
Kafka
StreamTableSource for Kafka 0.8. |
class |
Kafka08TableSource
Kafka
StreamTableSource for Kafka 0.8. |
class |
Kafka09AvroTableSource
Kafka
StreamTableSource for Kafka 0.9. |
class |
Kafka09JsonTableSink
Kafka 0.9
KafkaTableSink that serializes data in JSON format. |
class |
Kafka09JsonTableSource
Kafka
StreamTableSource for Kafka 0.9. |
class |
Kafka09TableSource
Kafka
StreamTableSource for Kafka 0.9. |
Constructor and Description |
---|
FlinkKafkaConsumer010(Pattern subscriptionPattern,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.10.x.
|
FlinkKafkaConsumer010(Pattern subscriptionPattern,
KeyedDeserializationSchema<T> deserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.10.x.
|
FlinkKafkaConsumer011(Pattern subscriptionPattern,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.11.x.
|
FlinkKafkaConsumer011(Pattern subscriptionPattern,
KeyedDeserializationSchema<T> deserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.11.x.
|
FlinkKafkaConsumer08(Pattern subscriptionPattern,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.8.x.
|
FlinkKafkaConsumer08(Pattern subscriptionPattern,
KeyedDeserializationSchema<T> deserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.8.x.
|
FlinkKafkaConsumer09(Pattern subscriptionPattern,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.9.x.
|
FlinkKafkaConsumer09(Pattern subscriptionPattern,
KeyedDeserializationSchema<T> deserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.9.x.
|
Modifier and Type | Class and Description |
---|---|
class |
FlinkKafkaProducer<K,V>
Wrapper around KafkaProducer that allows to resume transactions in case of node failure, which allows to implement
two phase commit algorithm for exactly-once semantic FlinkKafkaProducer.
|
Modifier and Type | Class and Description |
---|---|
class |
KafkaTopicPartition
Flink's description of a partition in a Kafka topic.
|
Modifier and Type | Class and Description |
---|---|
class |
FlinkFixedPartitioner<T>
A partitioner ensuring that each internal Flink partition ends up in one Kafka partition.
|
class |
FlinkKafkaPartitioner<T>
A
FlinkKafkaPartitioner wraps logic on how to partition records
across partitions of multiple Kafka topics. |
Modifier and Type | Class and Description |
---|---|
class |
PythonDataStream<D extends DataStream<org.python.core.PyObject>>
A
PythonDataStream is a thin wrapper layer over DataStream , which represents a
stream of elements of the same type. |
class |
PythonIterativeStream
A thin wrapper layer over
IterativeStream . |
class |
PythonSplitStream
A thin wrapper layer over
SplitStream . |
Modifier and Type | Method and Description |
---|---|
void |
PythonDataStream.add_sink(SinkFunction<org.python.core.PyObject> sink_func)
A thin wrapper layer over
DataStream.addSink(SinkFunction) . |
PythonIterativeStream |
PythonDataStream.iterate()
A thin wrapper layer over
DataStream.iterate() . |
PythonIterativeStream |
PythonDataStream.iterate(Long max_wait_time_ms)
A thin wrapper layer over
DataStream.iterate(long) . |
void |
PythonDataStream.output()
A thin wrapper layer over
DataStream.print() . |
void |
PythonDataStream.write_as_text(String path)
A thin wrapper layer over
DataStream.writeAsText(java.lang.String) . |
void |
PythonDataStream.write_as_text(String path,
FileSystem.WriteMode mode)
A thin wrapper layer over
DataStream#writeAsText(java.lang.String, WriteMode) . |
void |
PythonDataStream.write_to_socket(String host,
Integer port,
SerializationSchema<org.python.core.PyObject> schema)
A thin wrapper layer over
DataStream.writeToSocket(String, int, org.apache.flink.api.common.serialization.SerializationSchema) . |
Modifier and Type | Class and Description |
---|---|
class |
PythonStreamExecutionEnvironment
A thin wrapper layer over
StreamExecutionEnvironment . |
Modifier and Type | Class and Description |
---|---|
class |
TimestampedValue<T>
Stores the value and the timestamp of the record.
|
Modifier and Type | Class and Description |
---|---|
class |
LatencyMarker
Special record type carrying a timestamp of its creation time at a source operator
and the vertexId and subtask index of the operator.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractDeserializationSchema<T>
Deprecated.
Use
AbstractDeserializationSchema instead. |
class |
JSONDeserializationSchema
Deprecated.
Please use
JsonNodeDeserializationSchema in the "flink-json" module. |
class |
JSONKeyValueDeserializationSchema
DeserializationSchema that deserializes a JSON String into an ObjectNode.
|
class |
JsonRowDeserializationSchema
Deprecated.
Please use
JsonRowDeserializationSchema in
the "flink-json" module. |
class |
JsonRowSerializationSchema
Deprecated.
Please use
JsonRowSerializationSchema in
the "flink-json" module. |
interface |
KeyedDeserializationSchema<T>
The deserialization schema describes how to turn the byte key / value messages delivered by certain
data sources (for example Apache Kafka) into data types (Java/Scala objects) that are
processed by Flink.
|
interface |
KeyedSerializationSchema<T>
The serialization schema describes how to turn a data object into a different serialized
representation.
|
class |
SimpleStringSchema
Deprecated.
Use
SimpleStringSchema instead. |
Modifier and Type | Class and Description |
---|---|
class |
JavaToValueConverter |
interface |
Key<T>
Deprecated.
The Key type is a relict of a deprecated and removed API and will be removed
in future (2.0) versions as well.
|
class |
Row
A Row can have arbitrary number of fields and contain a set of fields, which may all be
different types.
|
Modifier and Type | Class and Description |
---|---|
class |
BigDecParser
Parses a text field into a
BigDecimal . |
class |
BigIntParser
Parses a text field into a
BigInteger . |
class |
BooleanParser |
class |
BooleanValueParser |
class |
ByteParser |
class |
ByteValueParser
Parses a decimal text field into a
ByteValue . |
class |
DoubleParser
Parses a text field into a Double.
|
class |
DoubleValueParser
Parses a text field into a DoubleValue.
|
class |
FieldParser<T>
A FieldParser is used parse a field from a sequence of bytes.
|
class |
FloatParser
Parses a text field into a
Float . |
class |
FloatValueParser
Parses a text field into a
FloatValue |
class |
IntParser
Parses a decimal text field into a IntValue.
|
class |
IntValueParser
Parses a decimal text field into a IntValue.
|
class |
LongParser
Parses a decimal text field into a LongValue.
|
class |
LongValueParser
Parses a decimal text field into a LongValue.
|
class |
ShortParser
Parses a decimal text field into a
Short . |
class |
ShortValueParser
Parses a decimal text field into a
ShortValue . |
class |
SqlDateParser
Parses a text field into a
Date . |
class |
SqlTimeParser
Parses a text field into a
Time . |
class |
SqlTimestampParser
Parses a text field into a
Timestamp . |
class |
StringParser
Converts a variable length field of a byte array into a
String . |
class |
StringValueParser
Converts a variable length field of a byte array into a
StringValue . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractID
A statistically unique identification number.
|
class |
OutputTag<T>
An
OutputTag is a typed and named tag to use for tagging side outputs
of an operator. |
class |
StringUtils
Utility class to convert objects into strings in vice-versa.
|
class |
StringValueUtils
Utility class for efficient operations on
StringValue . |
class |
TernaryBoolean
A ternary boolean, which can have the values 'true', 'false', or 'undefined'.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ThrowingRunnable<E extends Throwable>
Similar to a
Runnable , this interface is used to capture a block of code
to be executed. |
interface |
TriConsumer<S,T,U>
Operation which is performed on three given arguments.
|
interface |
TriFunction<S,T,U,R>
Function which takes three arguments.
|
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.