Modifier and Type | Class and Description |
---|---|
class |
BatchShuffleMode
Defines how data is exchanged between tasks in batch
ExecutionOptions.RUNTIME_MODE if the
shuffling behavior has not been set explicitly for an individual exchange. |
class |
CodeAnalysisMode
Deprecated.
The code analysis code has been removed and this enum has no effect. NOTE It
can not be removed from the codebase for now, because it had been serialized as part of the
ExecutionConfig which in turn had been serialized as part of the PojoSerializer .
This class can be removed when we drop support for pre 1.8 serializer snapshots that
contained java serialized serializers ( |
class |
InputDependencyConstraint
Deprecated.
InputDependencyConstraint is not used anymore and will be deleted in one of
the future versions. It was previously used in the scheduler implementations that were
removed as part of FLINK-20589. |
class |
JobStatus
Possible states of a job once it has been accepted by the dispatcher.
|
interface |
ProgramDescription
Implementing this interface allows a Program to have a description of the plan which can be shown
to the user.
|
class |
RuntimeExecutionMode
Runtime execution mode of DataStream programs.
|
Modifier and Type | Method and Description |
---|---|
long |
ExecutionConfig.getAutoWatermarkInterval()
Returns the interval of the automatic watermark emission.
|
InputDependencyConstraint |
ExecutionConfig.getDefaultInputDependencyConstraint()
Deprecated.
due to the deprecation of
InputDependencyConstraint . |
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.
|
ExecutionConfig |
ExecutionConfig.setAutoWatermarkInterval(long interval)
Sets the interval of the automatic watermark emission.
|
void |
ExecutionConfig.setDefaultInputDependencyConstraint(InputDependencyConstraint ignored)
Deprecated.
due to the deprecation of
InputDependencyConstraint . |
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 |
SerializableTimestampAssigner<T>
A
TimestampAssigner that is also Serializable . |
interface |
TimestampAssignerSupplier<T>
A supplier for
TimestampAssigners . |
class |
WatermarkAlignmentParams
Configuration parameters for watermark alignment.
|
interface |
WatermarkGeneratorSupplier<T>
A supplier for
WatermarkGenerators . |
Modifier and Type | Interface and Description |
---|---|
interface |
ExternalResourceDriver
Driver which takes the responsibility to manage and provide the information of external resource.
|
interface |
ExternalResourceDriverFactory
Factory for
ExternalResourceDriver . |
interface |
ExternalResourceInfo
Contains the information of an external resource.
|
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. |
class |
RichAggregateFunction<IN,ACC,OUT>
Rich variant of the
AggregateFunction . |
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.
|
DoubleCounter |
RuntimeContext.getDoubleCounter(String name)
Convenience function to create a counter object for doubles.
|
Set<ExternalResourceInfo> |
RuntimeContext.getExternalResourceInfos(String resourceName)
Get the specific external resource information by the resourceName.
|
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.
|
OperatorMetricGroup |
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 . |
void |
RuntimeContext.registerUserCodeClassLoaderReleaseHookIfAbsent(String releaseHookName,
Runnable releaseHook)
Registers a custom hook for the user code class loader release.
|
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
AbstractRuntimeUDFContext.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties) |
<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.
|
Tuple2<Long,Long> |
BinaryInputFormat.getCurrentState() |
Long |
DelimitedInputFormat.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 | Interface and Description |
---|---|
interface |
FlinkConnectorRateLimiter
An interface to create a ratelimiter
|
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 | Interface and Description |
---|---|
interface |
MailboxExecutor
Executor like interface for an build around a mailbox-based
execution model. |
interface |
ProcessingTimeService
A service that allows to get the current processing time and register timers that will execute
the given
ProcessingTimeService.ProcessingTimeCallback when firing. |
static interface |
ProcessingTimeService.ProcessingTimeCallback
A callback that can be registered via
ProcessingTimeService.registerTimer(long, ProcessingTimeCallback) . |
class |
SlotSharingGroup
Describe the name and the different resource components of a slot sharing group.
|
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.
|
interface |
BulkWriter<T>
An encoder that encodes data in a bulk fashion, encoding many records together at a time.
|
static interface |
DeserializationSchema.InitializationContext
A contextual information provided for
DeserializationSchema.open(InitializationContext) method. |
interface |
Encoder<IN>
A
Encoder is used by the streaming file sink to perform the actual writing of the
incoming elements to the files in a bucket. |
static interface |
SerializationSchema.InitializationContext
A contextual information provided for
SerializationSchema.open(InitializationContext) method. |
class |
SimpleStringEncoder<IN>
A simple
Encoder that uses toString() on the input elements and writes them to
the output bucket file separated by newline. |
class |
SimpleStringSchema
Very simple serialization schema for strings.
|
Modifier and Type | Method and Description |
---|---|
default void |
DeserializationSchema.deserialize(byte[] message,
Collector<T> out)
Deserializes the byte message.
|
default void |
DeserializationSchema.open(DeserializationSchema.InitializationContext context)
Initialization method for the schema.
|
default void |
SerializationSchema.open(SerializationSchema.InitializationContext context)
Initialization method for the schema.
|
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 |
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.
|
class |
StateTtlConfig
Configuration of state TTL logic.
|
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> 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 |
LocalTimeTypeInfo<T extends java.time.temporal.Temporal>
Type information for Java LocalDate/LocalTime/LocalDateTime.
|
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 |
---|---|
PrimitiveArrayComparator<T,?> |
PrimitiveArrayTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
TypeComparator<T> |
BasicTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
TypeSerializer<T> |
BasicArrayTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<Nothing> |
NothingTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
PrimitiveArrayTypeInfo.createSerializer(ExecutionConfig executionConfig) |
abstract TypeSerializer<T> |
TypeInformation.createSerializer(ExecutionConfig config)
Creates a serializer for the type.
|
TypeSerializer<T> |
BasicTypeInfo.createSerializer(ExecutionConfig executionConfig) |
int |
BasicArrayTypeInfo.getArity() |
int |
NothingTypeInfo.getArity() |
int |
PrimitiveArrayTypeInfo.getArity() |
abstract int |
TypeInformation.getArity()
Gets the arity of this type - the number of fields without nesting.
|
int |
BasicTypeInfo.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> PrimitiveArrayTypeInfo<X> |
PrimitiveArrayTypeInfo.getInfoFor(Class<X> type)
Tries to get the PrimitiveArrayTypeInfo for an array.
|
static <X> BasicTypeInfo<X> |
BasicTypeInfo.getInfoFor(Class<X> type) |
static <X,C> BasicArrayTypeInfo<X,C> |
BasicArrayTypeInfo.getInfoFor(Class<X> type) |
int |
BasicArrayTypeInfo.getTotalFields() |
int |
NothingTypeInfo.getTotalFields() |
int |
PrimitiveArrayTypeInfo.getTotalFields() |
abstract int |
TypeInformation.getTotalFields()
Gets the number of logical fields in this type.
|
int |
BasicTypeInfo.getTotalFields() |
Class<T> |
BasicArrayTypeInfo.getTypeClass() |
Class<Nothing> |
NothingTypeInfo.getTypeClass() |
Class<T> |
PrimitiveArrayTypeInfo.getTypeClass() |
abstract Class<T> |
TypeInformation.getTypeClass()
Gets the class of the type represented by this type information.
|
Class<T> |
BasicTypeInfo.getTypeClass() |
boolean |
BasicArrayTypeInfo.isBasicType() |
boolean |
NothingTypeInfo.isBasicType() |
boolean |
PrimitiveArrayTypeInfo.isBasicType() |
abstract boolean |
TypeInformation.isBasicType()
Checks if this type information represents a basic type.
|
boolean |
BasicTypeInfo.isBasicType() |
boolean |
BasicArrayTypeInfo.isKeyType() |
boolean |
NothingTypeInfo.isKeyType() |
boolean |
PrimitiveArrayTypeInfo.isKeyType() |
abstract boolean |
TypeInformation.isKeyType()
Checks whether this type can be used as a key.
|
boolean |
BasicTypeInfo.isKeyType() |
boolean |
TypeInformation.isSortKeyType()
Checks whether this type can be used as a key for sorting.
|
boolean |
BasicArrayTypeInfo.isTupleType() |
boolean |
NothingTypeInfo.isTupleType() |
boolean |
PrimitiveArrayTypeInfo.isTupleType() |
abstract boolean |
TypeInformation.isTupleType()
Checks if this type information represents a Tuple type.
|
boolean |
BasicTypeInfo.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 |
---|---|
static class |
CompositeType.FlatFieldDescriptor |
static class |
CompositeType.InvalidFieldReferenceException |
protected static interface |
CompositeType.TypeComparatorBuilder<T> |
class |
CompositeTypeComparator<T> |
class |
CompositeTypeSerializerSnapshot<T,S extends TypeSerializer<T>>
A
CompositeTypeSerializerSnapshot is a convenient serializer snapshot class that can be
used by simple serializers which 1) delegates its serialization to multiple nested serializers,
and 2) may contain some extra static information that needs to be persisted as part of its
snapshot. |
class |
SimpleTypeSerializerSnapshot<T>
A simple base class for TypeSerializerSnapshots, for serializers that have no parameters.
|
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<T>
Deprecated.
|
class |
TypeSerializerSchemaCompatibility<T>
A
TypeSerializerSchemaCompatibility represents information about whether or not a TypeSerializer can be safely used to read data written by a previous type serializer. |
interface |
TypeSerializerSnapshot<T>
A
TypeSerializerSnapshot 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 | Interface and Description |
---|---|
interface |
Committer<CommT>
Deprecated.
Please use
Committer . |
interface |
GlobalCommitter<CommT,GlobalCommT>
Deprecated.
Please use
WithPostCommitTopology with StandardSinkTopologies#addGlobalCommitter . |
interface |
Sink<InputT,CommT,WriterStateT,GlobalCommT>
Deprecated.
Please use
Sink or a derivative. |
static interface |
Sink.InitContext
Deprecated.
Please migrate to
Sink and use
Sink.InitContext . |
static interface |
Sink.ProcessingTimeService
Deprecated.
Please migrate to
Sink and use
ProcessingTimeService . |
static interface |
Sink.ProcessingTimeService.ProcessingTimeCallback
Deprecated.
Please migrate to
Sink and use
ProcessingTimeService.ProcessingTimeCallback . |
interface |
SinkWriter<InputT,CommT,WriterStateT>
Deprecated.
Please use
SinkWriter or a derivative. |
static interface |
SinkWriter.Context
Deprecated.
Please migrate to
SinkWriter and use
SinkWriter.Context . |
Modifier and Type | Interface and Description |
---|---|
interface |
Committer<CommT>
The
Committer is responsible for committing the data staged by the TwoPhaseCommittingSink.PrecommittingSinkWriter in the second step of a two-phase commit
protocol. |
static interface |
Committer.CommitRequest<CommT>
A request to commit a specific committable.
|
interface |
Sink<InputT>
Base interface for developing a sink.
|
static interface |
Sink.InitContext
The interface exposes some runtime info for creating a
SinkWriter . |
interface |
SinkWriter<InputT>
The
SinkWriter is responsible for writing data. |
static interface |
SinkWriter.Context
Context that
SinkWriter.write(InputT, org.apache.flink.api.connector.sink2.SinkWriter.Context) can use for getting additional data about an input record. |
interface |
StatefulSink<InputT,WriterStateT>
A
Sink with a stateful SinkWriter . |
static interface |
StatefulSink.StatefulSinkWriter<InputT,WriterStateT>
A
SinkWriter whose state needs to be checkpointed. |
static interface |
StatefulSink.WithCompatibleState
A mix-in for
StatefulSink that allows users to migrate from a sink with a compatible
state to this sink. |
interface |
TwoPhaseCommittingSink<InputT,CommT>
A
Sink for exactly-once semantics using a two-phase commit protocol. |
static interface |
TwoPhaseCommittingSink.PrecommittingSinkWriter<InputT,CommT>
A
SinkWriter that performs the first part of a two-phase commit protocol. |
Modifier and Type | Interface and Description |
---|---|
interface |
ExternallyInducedSourceReader<T,SplitT extends SourceSplit>
Sources that implement this interface delay checkpoints when receiving a trigger message from the
checkpoint coordinator to the point when their input data/events indicate that a checkpoint
should be triggered.
|
Modifier and Type | Class and Description |
---|---|
class |
CollectionEnvironment
Version of
ExecutionEnvironment that allows serial, local, collection-based executions of
Flink programs. |
Modifier and Type | Method and Description |
---|---|
void |
ExecutionEnvironment.clearJobListeners()
Clear all registered
JobListener s. |
void |
ExecutionEnvironment.configure(ReadableConfig configuration,
ClassLoader classLoader)
Sets all relevant options contained in the
ReadableConfig such as e.g. |
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. |
JobClient |
ExecutionEnvironment.executeAsync()
Triggers the program execution asynchronously.
|
JobClient |
ExecutionEnvironment.executeAsync(String jobName)
Triggers the program execution asynchronously.
|
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.
|
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.registerJobListener(JobListener jobListener)
Register a
JobListener in this environment. |
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.
|
Constructor and Description |
---|
ExecutionEnvironment(Configuration configuration)
Creates a new
ExecutionEnvironment that will use the given Configuration to
configure the PipelineExecutor . |
ExecutionEnvironment(Configuration configuration,
ClassLoader userClassloader)
Creates a new
ExecutionEnvironment that will use the given Configuration to
configure the PipelineExecutor . |
ExecutionEnvironment(PipelineExecutorServiceLoader executorServiceLoader,
Configuration configuration,
ClassLoader userClassloader)
Creates a new
ExecutionEnvironment that will use the given Configuration to
configure the PipelineExecutor . |
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.
|
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 |
IterativeDataSet.getAggregators()
Gets the registry for aggregators.
|
AggregatorRegistry |
DeltaIteration.getAggregators()
Gets the registry for aggregators for the iteration.
|
ResourceSpec |
DataSink.getMinResources()
Returns the minimum resources of this data sink.
|
ResourceSpec |
DeltaIteration.getMinResources()
Gets the minimum resources from this iteration.
|
ResourceSpec |
DataSink.getPreferredResources()
Returns the preferred resources of this data sink.
|
ResourceSpec |
DeltaIteration.getPreferredResources()
Gets the preferred resources from this iteration.
|
SplitDataProperties<OUT> |
DataSource.getSplitDataProperties()
Returns the
SplitDataProperties for the InputSplit s of this DataSource for configurations. |
<X extends Value> |
IterativeDataSet.registerAggregationConvergenceCriterion(String name,
Aggregator<X> aggregator,
ConvergenceCriterion<X> convergenceCheck)
Registers an
Aggregator for the iteration together with a ConvergenceCriterion . |
<X extends Value> |
DeltaIteration.registerAggregationConvergenceCriterion(String name,
Aggregator<X> aggregator,
ConvergenceCriterion<X> convergenceCheck)
Registers an
Aggregator for the iteration together with a ConvergenceCriterion . |
IterativeDataSet<T> |
IterativeDataSet.registerAggregator(String name,
Aggregator<?> aggregator)
Registers an
Aggregator for the iteration. |
DeltaIteration<ST,WT> |
DeltaIteration.registerAggregator(String name,
Aggregator<?> aggregator)
Registers an
Aggregator for the iteration. |
DistinctOperator<T> |
DistinctOperator.setCombineHint(ReduceOperatorBase.CombineHint strategy)
Sets the strategy to use for the combine phase of the reduce.
|
ReduceOperator<IN> |
ReduceOperator.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 |
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> |
EnumTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
TypeComparator<T> |
GenericTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
TypeComparator<T> |
ValueTypeInfo.createComparator(boolean sortOrderAscending,
ExecutionConfig executionConfig) |
TypeSerializer<T> |
WritableTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
EnumTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
ObjectArrayTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<Either<L,R>> |
EitherTypeInfo.createSerializer(ExecutionConfig config) |
TypeSerializer<T> |
GenericTypeInfo.createSerializer(ExecutionConfig config) |
TypeSerializer<T> |
ValueTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TupleSerializer<T> |
TupleTypeInfo.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 |
EnumTypeInfo.getArity() |
int |
ObjectArrayTypeInfo.getArity() |
int |
EitherTypeInfo.getArity() |
int |
GenericTypeInfo.getArity() |
int |
ValueTypeInfo.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[] 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) |
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 |
EnumTypeInfo.getTotalFields() |
int |
ObjectArrayTypeInfo.getTotalFields() |
int |
EitherTypeInfo.getTotalFields() |
int |
GenericTypeInfo.getTotalFields() |
int |
ValueTypeInfo.getTotalFields() |
int |
PojoTypeInfo.getTotalFields() |
<X> TypeInformation<X> |
PojoTypeInfo.getTypeAt(int pos) |
<X> TypeInformation<X> |
PojoTypeInfo.getTypeAt(String fieldExpression) |
Class<T> |
WritableTypeInfo.getTypeClass() |
Class<T> |
EnumTypeInfo.getTypeClass() |
Class<T> |
ObjectArrayTypeInfo.getTypeClass() |
Class<Either<L,R>> |
EitherTypeInfo.getTypeClass() |
Class<T> |
GenericTypeInfo.getTypeClass() |
Class<T> |
ValueTypeInfo.getTypeClass() |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getUnaryOperatorReturnType(Function function,
Class<?> baseClass,
int inputTypeArgumentIndex,
int outputTypeArgumentIndex,
int[] lambdaOutputTypeArgumentIndices,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing)
Returns the unary operator's return type.
|
boolean |
WritableTypeInfo.isBasicType() |
boolean |
EnumTypeInfo.isBasicType() |
boolean |
ObjectArrayTypeInfo.isBasicType() |
boolean |
EitherTypeInfo.isBasicType() |
boolean |
GenericTypeInfo.isBasicType() |
boolean |
ValueTypeInfo.isBasicType() |
boolean |
PojoTypeInfo.isBasicType() |
boolean |
ValueTypeInfo.isBasicValueType() |
boolean |
WritableTypeInfo.isKeyType() |
boolean |
EnumTypeInfo.isKeyType() |
boolean |
ObjectArrayTypeInfo.isKeyType() |
boolean |
EitherTypeInfo.isKeyType() |
boolean |
GenericTypeInfo.isKeyType() |
boolean |
ValueTypeInfo.isKeyType() |
boolean |
PojoTypeInfo.isSortKeyType() |
boolean |
WritableTypeInfo.isTupleType() |
boolean |
EnumTypeInfo.isTupleType() |
boolean |
ObjectArrayTypeInfo.isTupleType() |
boolean |
EitherTypeInfo.isTupleType() |
boolean |
GenericTypeInfo.isTupleType() |
boolean |
ValueTypeInfo.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 |
MultipleParameterTool
This class provides simple utility methods for reading and parsing program arguments from
different sources.
|
Modifier and Type | Method and Description |
---|---|
Set<String> |
AbstractParameterTool.getUnrequestedParameters()
Returns the set of parameter names which have not been requested with
AbstractParameterTool.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 |
PatternProcessFunction<IN,OUT>
It is called with a map of detected events which are identified by their names.
|
interface |
TimedOutPartialMatchHandler<IN>
Enables handling timed out partial matches.
|
Modifier and Type | Class and Description |
---|---|
class |
IterativeCondition<T>
A user-defined condition that decides if an element should be accepted in the pattern or not.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TimeContext
Enables access to time related characteristics such as current processing time or timestamp of
currently processed element.
|
Modifier and Type | Class and Description |
---|---|
class |
ClientOptions
Describes a client configuration parameter.
|
Modifier and Type | Class and Description |
---|---|
class |
ApplicationExecutionException
A
FlinkException thrown in case something during application execution went wrong. |
class |
WebSubmissionJobClient
A
JobClient that only allows asking for the job id of the job it is attached to. |
Modifier and Type | Class and Description |
---|---|
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. |
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 | Class and Description |
---|---|
class |
AkkaOptions
Akka configuration options.
|
class |
BlobServerOptions
Configuration options for the BlobServer and BlobCache.
|
class |
CleanupOptions
ConfigOption collection for the configuration of repeatable cleanup of resource cleanup
after a job reached a globally-terminated state. |
class |
ClusterOptions
Options which control the cluster behaviour.
|
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 |
DeploymentOptions
The
configuration options relevant for all Executors. |
interface |
DescribedEnum
Describe enum constants used in
ConfigOption s. |
class |
ExecutionOptions
ConfigOption s specific for a single execution of a user program. |
class |
ExternalResourceOptions
Configuration options for external resources and external resource drivers.
|
class |
HeartbeatManagerOptions
The set of configuration options relating to heartbeat manager 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 |
JMXServerOptions
The set of configuration options relating to JMX server.
|
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 |
NettyShuffleEnvironmentOptions
The set of configuration options relating to network stack.
|
class |
OptimizerOptions
Configuration options for the optimizer.
|
class |
PipelineOptions
The
configuration options for job execution. |
static class |
PipelineOptions.VertexDescriptionMode
The mode how we organize description of a vertex.
|
class |
QueryableStateOptions
The set of configuration options relating to Queryable State.
|
interface |
ReadableConfig
Read access to a configuration object.
|
class |
ResourceManagerOptions
The set of configuration options relating to the ResourceManager.
|
class |
RestartStrategyOptions
Config options for restart strategies.
|
class |
StateChangelogOptions
A collection of all configuration options that relate to changelog.
|
class |
TaskManagerOptions
The set of configuration options relating to TaskManager and Task settings.
|
class |
WebOptions
Configuration options for the WebMonitorEndpoint.
|
interface |
WritableConfig
Write access to a configuration object.
|
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 . |
<T extends Enum<T>> |
Configuration.getEnum(Class<T> enumClass,
ConfigOption<String> configOption)
Returns the value associated with the given config option as an enum.
|
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 | Class and Description |
---|---|
class |
AWSConfigConstants
Configuration keys for AWS service usage.
|
Modifier and Type | Class and Description |
---|---|
class |
AsyncClientOptionsUtils
Class for handling Kinesis async client specific options.
|
class |
AWSOptionUtils
Handler for AWS specific table options.
|
Modifier and Type | Class and Description |
---|---|
class |
DeliveryGuarantee
DeliverGuarantees that can be chosen.
|
Modifier and Type | Class and Description |
---|---|
class |
AsyncSinkBase<InputT,RequestEntryT extends Serializable>
A generic sink for destinations that provide an async client to persist data.
|
class |
AsyncSinkBaseBuilder<InputT,RequestEntryT extends Serializable,ConcreteBuilderT extends AsyncSinkBaseBuilder<?,?,?>>
Abstract builder for constructing a concrete implementation of
AsyncSinkBase . |
Modifier and Type | Class and Description |
---|---|
class |
AsyncSinkWriter<InputT,RequestEntryT extends Serializable>
A generic sink writer that handles the general behaviour of a sink such as batching and flushing,
and allows extenders to implement the logic for persisting individual request elements, with
allowance for retries.
|
class |
AsyncSinkWriterStateSerializer<RequestEntryT extends Serializable>
Serializer class for
AsyncSinkWriter state. |
class |
BufferedRequestState<RequestEntryT extends Serializable>
Class holding state of
AsyncSinkWriter needed at taking a snapshot. |
interface |
ElementConverter<InputT,RequestEntryT>
This interface specifies the mapping between elements of a stream to request entries that can be
sent to the destination.
|
class |
RequestEntryWrapper<RequestEntryT>
A wrapper that contains a
RequestEntryT ready to be written by the Sink Writer class,
along with the size of that entry as defined by the method getSizeInBytes(RequestEntryT)
of the AsyncSinkWriter . |
Modifier and Type | Class and Description |
---|---|
class |
HybridSource<T>
Hybrid source that switches underlying sources based on configured source chain.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RecordEmitter<E,T,SplitStateT>
Emit a record to the downstream.
|
class |
RecordsBySplits<E>
An implementation of RecordsWithSplitIds to host all the records by splits.
|
interface |
RecordsWithSplitIds<E>
An interface for the elements passed from the fetchers to the source reader.
|
class |
SingleThreadMultiplexSourceReaderBase<E,T,SplitT extends SourceSplit,SplitStateT>
A base for
SourceReader s that read splits with one thread using one SplitReader . |
class |
SourceReaderBase<E,T,SplitT extends SourceSplit,SplitStateT>
An abstract implementation of
SourceReader which provides some synchronization between
the mail box main thread and the SourceReader internal threads. |
class |
SourceReaderOptions
The options that can be set for the
SourceReaderBase . |
Modifier and Type | Interface and Description |
---|---|
interface |
SplitReader<E,SplitT extends SourceSplit>
An interface used to read from splits.
|
class |
SplitsAddition<SplitT>
A change to add splits.
|
class |
SplitsChange<SplitT>
An abstract class to host splits change.
|
Modifier and Type | Class and Description |
---|---|
class |
AsyncDynamicTableSinkFactory
Abstract Implementation of
DynamicTableSinkFactory having AsyncSinkBase fields as
optional table options defined in AsyncSinkConnectorOptions . |
class |
AsyncSinkConnectorOptions
Optional Options for
AsyncDynamicTableSinkFactory representing fields of AsyncSinkBase . |
Modifier and Type | Interface and Description |
---|---|
interface |
ConfigurationValidator
Interface for classes that validate connector specific table options, including common utils for
validation.
|
interface |
TableOptionsUtils
Interface for handling specific set of table options.
|
Modifier and Type | Class and Description |
---|---|
class |
AsyncDynamicTableSink<RequestEntryT extends Serializable>
Abstract wrapper class for
DynamicTableSink with attributes of AsyncSinkBase . |
class |
AsyncDynamicTableSinkBuilder<RequestEntryT extends Serializable,ConcreteBuilderT extends AsyncDynamicTableSinkBuilder<?,?>>
Builder class for
AsyncDynamicTableSink . |
Modifier and Type | Class and Description |
---|---|
class |
AsyncSinkConfigurationValidator
Class for validating options in
AsyncSinkConnectorOptions . |
Modifier and Type | Class and Description |
---|---|
class |
ConfigurationValidatorUtil
Class containing validation utils needed by
ConfigurationValidator . |
Modifier and Type | Class and Description |
---|---|
class |
DataGenConnectorOptions
Options for the DataGen connector.
|
Modifier and Type | Class and Description |
---|---|
class |
Elasticsearch6SinkBuilder<IN>
Builder to construct an Elasticsearch 6 compatible
ElasticsearchSink . |
class |
Elasticsearch7SinkBuilder<IN>
Builder to construct an Elasticsearch 7 compatible
ElasticsearchSink . |
interface |
ElasticsearchEmitter<T>
Creates none or multiple
ActionRequests from the incoming elements. |
class |
ElasticsearchSink<IN>
Flink Sink to insert or update data in an Elasticsearch index.
|
class |
ElasticsearchSinkBuilderBase<IN,B extends ElasticsearchSinkBuilderBase<IN,B>>
Base builder to construct a
ElasticsearchSink . |
class |
FlushBackoffType
Used to control whether the sink should retry failed requests at all or with which kind back off
strategy.
|
interface |
RequestIndexer
Users add multiple delete, index or update requests to a
RequestIndexer to prepare them
for sending to an Elasticsearch cluster. |
Modifier and Type | Class and Description |
---|---|
class |
Elasticsearch6ConnectorOptions
Options specific for the Elasticsearch 6 connector.
|
class |
ElasticsearchConnectorOptions
Base options for the Elasticsearch connector.
|
Modifier and Type | Class and Description |
---|---|
static class |
FileSink.BulkFormatBuilder<IN,T extends FileSink.BulkFormatBuilder<IN,T>>
A builder for configuring the sink for bulk-encoding formats, e.g.
|
Modifier and Type | Class and Description |
---|---|
class |
ConcatFileCompactor
A
OutputStreamBasedFileCompactor implementation that simply concat the compacting files. |
class |
DecoderBasedReader<T>
A
RecordWiseFileCompactor.Reader implementation that reads the file as an FSDataInputStream and decodes the record with the DecoderBasedReader.Decoder . |
interface |
FileCompactor
The
FileCompactor is responsible for compacting files into one file. |
class |
FileCompactStrategy
Strategy for compacting the files written in
FileSink before committing. |
class |
InputFormatBasedReader<T>
A
RecordWiseFileCompactor.Reader implementation that reads the file using the FileInputFormat . |
class |
OutputStreamBasedFileCompactor
Base class for
FileCompactor implementations that write the compacting file by a output
stream. |
class |
RecordWiseFileCompactor<IN>
A
FileCompactor implementation that reads input files with a RecordWiseFileCompactor.Reader and writes
with a RecordWiseFileCompactor.Writer . |
static interface |
RecordWiseFileCompactor.Writer<T>
The writer that writers record into the compacting files.
|
class |
SimpleStringDecoder
A sink
DecoderBasedReader.Decoder that reads data encoded by the SimpleStringEncoder only for compaction. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractFileSource<T,SplitT extends FileSourceSplit>
The base class for File Sources.
|
class |
FileSource<T>
A unified data source that reads files - both in batch and in streaming mode.
|
class |
FileSourceSplit
A
SourceSplit that represents a file, or a region of a file. |
class |
FileSourceSplitSerializer
A serializer for the
FileSourceSplit . |
class |
FileSourceSplitState<SplitT extends FileSourceSplit>
State of the reader, essentially a mutable version of the
FileSourceSplit . |
class |
PendingSplitsCheckpoint<SplitT extends FileSourceSplit>
A checkpoint of the current state of the containing the currently pending splits that are not yet
assigned.
|
class |
PendingSplitsCheckpointSerializer<T extends FileSourceSplit>
A serializer for the
PendingSplitsCheckpoint . |
Modifier and Type | Interface and Description |
---|---|
interface |
FileSplitAssigner
The
FileSplitAssigner is responsible for deciding what split should be processed next by
which node. |
class |
LocalityAwareSplitAssigner
A
FileSplitAssigner that assigns to each host preferably splits that are local, before
assigning splits that are not local. |
class |
SimpleSplitAssigner
The
SimpleSplitAssigner hands out splits in a random order, without any consideration for
order or locality. |
Modifier and Type | Class and Description |
---|---|
class |
StandardDeCompressors
A collection of common compression formats and de-compressors.
|
Modifier and Type | Class and Description |
---|---|
class |
BlockSplittingRecursiveEnumerator
This
FileEnumerator enumerates all files under the given paths recursively, and creates a
separate split for each file block. |
class |
DefaultFileFilter
A file filter that filters out hidden files based on common naming patterns, i.e., files where
the filename starts with '.' or with '_'.
|
interface |
FileEnumerator
The
FileEnumerator 's task is to discover all files to be read and to split them into a
set of FileSourceSplit . |
class |
NonSplittingRecursiveEnumerator
This
FileEnumerator enumerates all files under the given paths recursively. |
Modifier and Type | Interface and Description |
---|---|
interface |
BulkFormat<T,SplitT extends FileSourceSplit>
The
BulkFormat reads and decodes batches of records at a time. |
interface |
FileRecordFormat<T>
Deprecated.
Please use
StreamFormat instead. The main motivation for removing it is the
inherent design flaw in the batching of FileRecordFormat: StreamFormat can guarantee that
only a certain amount of memory is being used (unless a single record exceeds that already),
but FileRecordFormat can only batch by the number of records. By removing FileRecordFormat,
we relay the responsibility of implementing the batching to the format developer; they need
to use BulkFormat and find a better way than batch by number of records. |
class |
SimpleStreamFormat<T>
A simple version of the
StreamFormat , for formats that are not splittable. |
interface |
StreamFormat<T>
A reader format that reads individual records from a stream.
|
static interface |
StreamFormat.Reader<T>
The actual reader that reads the records.
|
class |
TextLineInputFormat
A reader format that text lines from a file.
|
static class |
TextLineInputFormat.Reader
The actual reader for the
TextLineInputFormat . |
Modifier and Type | Class and Description |
---|---|
class |
ArrayResultIterator<E>
A simple
BulkFormat.RecordIterator that returns the elements of an array, one after the
other. |
class |
CheckpointedPosition
The position of a reader, to be stored in a checkpoint.
|
class |
IteratorResultIterator<E>
A simple
BulkFormat.RecordIterator that returns the elements of an iterator, augmented
with position information. |
class |
MutableRecordAndPosition<E>
A mutable version of the
RecordAndPosition . |
class |
Pool<T>
A pool to cache and recycle heavyweight objects, to reduce object allocation.
|
class |
RecordAndPosition<E>
A record, together with the reader position to be stored in the checkpoint.
|
class |
SingletonResultIterator<E>
A simple
BulkFormat.RecordIterator that returns a single value. |
class |
Utils
Miscellaneous utilities for the file source.
|
Modifier and Type | Class and Description |
---|---|
class |
FileSystemConnectorOptions
Options for the filesystem connector.
|
Modifier and Type | Class and Description |
---|---|
class |
KinesisFirehoseConfigConstants
Defaults for
KinesisFirehoseSinkWriter . |
class |
KinesisFirehoseSink<InputT>
A Kinesis Data Firehose (KDF) Sink that performs async requests against a destination delivery
stream using the buffering protocol specified in
AsyncSinkBase . |
class |
KinesisFirehoseSinkBuilder<InputT>
Builder to construct
KinesisFirehoseSink . |
Modifier and Type | Class and Description |
---|---|
class |
KinesisFirehoseConnectorOptions
Options for the Kinesis firehose connector.
|
Modifier and Type | Class and Description |
---|---|
class |
HBaseConnectorOptions
Options for the HBase connector.
|
Modifier and Type | Class and Description |
---|---|
class |
JdbcConnectionOptions
JDBC connection options.
|
class |
JdbcExactlyOnceOptions
JDBC exactly once sink options.
|
class |
JdbcExecutionOptions
JDBC sink batch options.
|
class |
JdbcSink
Facade to create JDBC
sinks . |
interface |
JdbcStatementBuilder<T>
Sets
PreparedStatement parameters to use in JDBC Sink based on a specific type of
StreamRecord. |
Modifier and Type | Class and Description |
---|---|
class |
JdbcCatalog
Catalogs for relational databases via JDBC.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JdbcRowConverter
Converter that is responsible to convert between JDBC object and Flink SQL internal data
structure
RowData . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDialect
Base class for
JdbcDialects that implements basic data type validation and
the construction of basic INSERT , UPDATE , DELETE , and SELECT
statements. |
interface |
JdbcDialect
Represents a dialect of SQL implemented by a particular JDBC system.
|
interface |
JdbcDialectFactory
A factory to create a specific
JdbcDialect . |
Modifier and Type | Interface and Description |
---|---|
interface |
FieldNamedPreparedStatement
This is a wrapper around
PreparedStatement and allows the users to set parameters by name
instead of by index. |
Modifier and Type | Class and Description |
---|---|
class |
JdbcConnectorOptions
Options for the JDBC connector.
|
Modifier and Type | Interface and Description |
---|---|
interface |
KafkaRecordSerializationSchema<T>
A serialization schema which defines how to convert a value of type
T to ProducerRecord . |
class |
KafkaRecordSerializationSchemaBuilder<IN>
Builder to construct
KafkaRecordSerializationSchema . |
class |
KafkaSink<IN>
Flink Sink to produce data into a Kafka topic.
|
class |
KafkaSinkBuilder<IN>
Builder to construct
KafkaSink . |
interface |
TopicSelector<IN>
Selects a topic for the incoming record.
|
Modifier and Type | Class and Description |
---|---|
class |
KafkaSource<OUT>
The Source implementation of Kafka.
|
class |
KafkaSourceBuilder<OUT>
The @builder class for
KafkaSource to make it easier for the users to construct a KafkaSource . |
Modifier and Type | Interface and Description |
---|---|
interface |
OffsetsInitializer
An interface for users to specify the starting / stopping offset of a
KafkaPartitionSplit . |
Modifier and Type | Class and Description |
---|---|
class |
KafkaSourceReaderMetrics
A collection class for handling metrics in
KafkaSourceReader . |
Modifier and Type | Interface and Description |
---|---|
interface |
KafkaRecordDeserializationSchema<T>
An interface for the deserialization of Kafka records.
|
Modifier and Type | Class and Description |
---|---|
class |
KinesisStreamsConfigConstants
Defaults for
KinesisStreamsSinkWriter . |
class |
KinesisStreamsSink<InputT>
A Kinesis Data Streams (KDS) Sink that performs async requests against a destination stream using
the buffering protocol specified in
AsyncSinkBase . |
class |
KinesisStreamsSinkBuilder<InputT>
Builder to construct
KinesisStreamsSink . |
interface |
PartitionKeyGenerator<InputT>
This is a serializable function whose
accept() method specifies how to convert from an
input element to the partition key, a string. |
Modifier and Type | Class and Description |
---|---|
class |
FixedKinesisPartitionKeyGenerator<T>
A partitioner ensuring that each internal Flink partition ends up in the same Kinesis partition.
|
class |
KinesisConnectorOptions
Options for the Kinesis connector.
|
class |
RandomKinesisPartitionKeyGenerator<T>
A
PartitionKeyGenerator that maps an arbitrary input element to a random
partition ID. |
Modifier and Type | Class and Description |
---|---|
class |
PrintConnectorOptions
Options for the Print sink connector.
|
Modifier and Type | Class and Description |
---|---|
class |
PulsarOptions
Configuration for Pulsar Client, these config options would be used for both source, sink and
table.
|
Modifier and Type | Class and Description |
---|---|
class |
PulsarSink<IN>
The Sink implementation of Pulsar.
|
class |
PulsarSinkBuilder<IN>
The builder class for
PulsarSink to make it easier for the users to construct a PulsarSink . |
class |
PulsarSinkOptions
Configurations for PulsarSink.
|
Modifier and Type | Class and Description |
---|---|
class |
SinkConfiguration
The configured class for pulsar sink.
|
Modifier and Type | Interface and Description |
---|---|
interface |
PulsarSinkContext
This context provides information on the pulsar record target location.
|
Modifier and Type | Class and Description |
---|---|
class |
FixedMessageDelayer<IN>
A delayer for making sure all the messages would be sent in a fixed delay duration.
|
interface |
MessageDelayer<IN>
A delayer for Pulsar broker passing the sent message to the downstream consumer.
|
Modifier and Type | Class and Description |
---|---|
class |
PulsarMessage<T>
The message instance would be used for
TypedMessageBuilder . |
class |
PulsarMessageBuilder<T>
TypedMessageBuilder wrapper for providing the required method for end-users. |
Modifier and Type | Class and Description |
---|---|
class |
MessageKeyHash
Predefined the available hash function for routing the message.
|
interface |
TopicRouter<IN>
The router for choosing the desired topic to write the Flink records.
|
class |
TopicRoutingMode
The routing policy for choosing the desired topic by the given message.
|
Modifier and Type | Interface and Description |
---|---|
interface |
PulsarSerializationSchema<IN>
The serialization schema for how to serialize records into Pulsar.
|
Modifier and Type | Class and Description |
---|---|
class |
PulsarSource<OUT>
The Source implementation of Pulsar.
|
class |
PulsarSourceBuilder<OUT>
The builder class for
PulsarSource to make it easier for the users to construct a PulsarSource . |
class |
PulsarSourceOptions
Configurations for PulsarSource.
|
Modifier and Type | Class and Description |
---|---|
class |
CursorVerification
The enum class for defining the cursor verify behavior.
|
class |
SourceConfiguration
The configuration class for pulsar source.
|
Modifier and Type | Class and Description |
---|---|
class |
CursorPosition
The class for defining the start or stop position.
|
interface |
StartCursor
A interface for users to specify the start position of a pulsar subscription.
|
interface |
StopCursor
A interface for users to specify the stop position of a pulsar subscription.
|
static class |
StopCursor.StopCondition
The conditional for control the stop behavior of the pulsar source.
|
Modifier and Type | Class and Description |
---|---|
class |
TopicMetadata
The pojo class for pulsar topic metadata information.
|
class |
TopicPartition
Topic partition is the basic topic information used by
SplitReader , we create this topic
metas for a specified topic by subscription type and convert it into a partition split. |
class |
TopicRange
This class is used to define the range for KeyShared subscription.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RangeGenerator
A generator for generating the
TopicRange for given topic. |
Modifier and Type | Interface and Description |
---|---|
interface |
PulsarDeserializationSchema<T>
A schema bridge for deserializing the pulsar's
Message<byte[]> into a flink managed
instance. |
Modifier and Type | Class and Description |
---|---|
class |
FlinkHiveException
Exception used by flink's hive data connector.
|
class |
HiveSource<T>
A unified data source that reads a hive table.
|
class |
HiveSourceBuilder
Builder to build
HiveSource instances. |
class |
HiveTablePartition
A class that describes a partition of a Hive table.
|
Modifier and Type | Class and Description |
---|---|
class |
HiveSourceSplit
A sub-class of
FileSourceSplit that contains extra information needed to read a hive
table. |
Modifier and Type | Class and Description |
---|---|
class |
EmbeddedRocksDBStateBackend
A
StateBackend that stores its state in an embedded RocksDB instance. |
class |
EmbeddedRocksDBStateBackendFactory
A factory that creates an
EmbeddedRocksDBStateBackend from a configuration. |
Modifier and Type | Interface and Description |
---|---|
interface |
JobClient
A client that is scoped to a specific job.
|
interface |
JobListener
A listener that is notified on specific job status changed, which should be firstly registered by
#registerJobListener of execution environments. |
class |
SavepointFormatType
Describes the binary format in which a savepoint should be taken.
|
Modifier and Type | Interface and Description |
---|---|
interface |
EntropyInjectingFileSystem
An interface to be implemented by a
FileSystem that is aware of entropy injection. |
class |
EntropyInjector
This class offers utilities for entropy injection for FileSystems that implement
EntropyInjectingFileSystem . |
interface |
FileSystemFactory
A factory to create file systems.
|
class |
FileSystemKind
An enumeration defining the kind and characteristics of a
FileSystem . |
class |
RecoverableFsDataOutputStream
An output stream to a file system that can be recovered at well defined points.
|
interface |
RecoverableWriter
The RecoverableWriter creates and recovers
RecoverableFsDataOutputStream . |
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. |
class |
InputStatus
An
InputStatus indicates the availability of data from an asynchronous input. |
class |
SimpleVersionedSerialization
Simple serialization / deserialization methods for the
SimpleVersionedSerializer . |
interface |
SimpleVersionedSerializer<E>
A simple serializer interface for versioned serialization.
|
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 | Interface and Description |
---|---|
interface |
Plugin
Interface for plugins.
|
Modifier and Type | Class and Description |
---|---|
class |
ScheduledDropwizardReporter
Base class for
MetricReporter that wraps a Dropwizard
Reporter . |
Modifier and Type | Class and Description |
---|---|
class |
AvroFormatOptions
Options for the avro format.
|
class |
AvroRowDataDeserializationSchema
Deserialization schema from Avro bytes to
RowData . |
class |
AvroRowDeserializationSchema
Deprecated.
The format was developed for the Table API users and will not be maintained for
DataStream API users anymore. Either use Table API or switch to Data Stream, defining your
own
DeserializationSchema . |
Modifier and Type | Class and Description |
---|---|
class |
GlueSchemaRegistryAvroDeserializationSchema<T>
AWS Glue Schema Registry Deserialization schema to de-serialize Avro binary format for Flink
Consumer user.
|
class |
GlueSchemaRegistryAvroSchemaCoder
Schema coder that allows reading schema that is somehow embedded into serialized record.
|
class |
GlueSchemaRegistryAvroSchemaCoderProvider
Provider for
GlueSchemaRegistryAvroSchemaCoder . |
class |
GlueSchemaRegistryAvroSerializationSchema<T>
AWS Glue Schema Registry Serialization schema to serialize to Avro binary format for Flink
Producer user.
|
class |
GlueSchemaRegistryInputStreamDeserializer
AWS Glue Schema Registry input stream de-serializer to accept input stream and extract schema
from it and remove schema registry information in the input stream.
|
class |
GlueSchemaRegistryOutputStreamSerializer
AWS Glue Schema Registry output stream serializer to accept schema and output stream to register
schema and write serialized object with schema registry bytes to output stream.
|
Modifier and Type | Class and Description |
---|---|
class |
AvroConfluentFormatOptions
Options for Schema Registry Avro format.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Converter<From,To,C>
A generic interface for converting data types.
|
Modifier and Type | Class and Description |
---|---|
class |
CompressWriterFactory<IN>
A factory that creates for
bulk writers that, when provided with a CompressionCodec , they compress the data they write. |
Modifier and Type | Class and Description |
---|---|
class |
CsvFormatOptions
Options for CSV format.
|
class |
CsvReaderFormat<T>
A
StreamFormat for reading CSV files. |
class |
CsvRowDataSerializationSchema
Serialization schema that serializes an object of Flink Table & SQL internal data structure into
a CSV bytes.
|
static class |
CsvRowDataSerializationSchema.Builder
A builder for creating a
CsvRowDataSerializationSchema . |
class |
CsvRowDeserializationSchema
Deprecated.
The format was developed for the Table API users and will not be maintained for
DataStream API users anymore. Either use Table API or switch to Data Stream, defining your
own
DeserializationSchema . |
static class |
CsvRowDeserializationSchema.Builder
Deprecated.
A builder for creating a
CsvRowDeserializationSchema . |
class |
CsvRowSerializationSchema
Deprecated.
The format was developed for the Table API users and will not be maintained for
DataStream API users anymore. Either use Table API or switch to Data Stream, defining your
own
SerializationSchema . |
static class |
CsvRowSerializationSchema.Builder
Deprecated.
A builder for creating a
CsvRowSerializationSchema . |
Modifier and Type | Class and Description |
---|---|
class |
JsonFormatOptions
Options for the JSON format.
|
class |
JsonNodeDeserializationSchema
DeserializationSchema that deserializes a JSON String into an ObjectNode.
|
class |
JsonRowDeserializationSchema
Deprecated.
The format was developed for the Table API users and will not be maintained for
DataStream API users anymore. Either use Table API or switch to Data Stream, defining your
own
DeserializationSchema . |
class |
JsonRowSerializationSchema
Deprecated.
The format was developed for the Table API users and will not be maintained for
DataStream API users anymore. Either use Table API or switch to Data Stream, defining your
own
SerializationSchema . |
static class |
JsonRowSerializationSchema.Builder
Deprecated.
Builder for
JsonRowSerializationSchema . |
Modifier and Type | Class and Description |
---|---|
class |
CanalJsonFormatOptions
Option utils for canal-json format.
|
Modifier and Type | Class and Description |
---|---|
class |
DebeziumJsonFormatOptions
Option utils for debezium-json format.
|
Modifier and Type | Class and Description |
---|---|
class |
GlueSchemaRegistryJsonDeserializationSchema<T>
AWS Glue Schema Registry Deserialization schema to de-serialize JSON Schema binary format for
Flink Consumer user.
|
class |
GlueSchemaRegistryJsonSchemaCoder
Schema coder that allows reading schema that is somehow embedded into serialized record.
|
class |
GlueSchemaRegistryJsonSchemaCoderProvider
Provider for
GlueSchemaRegistryJsonSchemaCoder . |
class |
GlueSchemaRegistryJsonSerializationSchema<T>
AWS Glue Schema Registry Serialization schema to serialize to JSON Schema binary format for Flink
Producer user.
|
Modifier and Type | Class and Description |
---|---|
class |
MaxwellJsonFormatOptions
Option utils for maxwell-json format.
|
Modifier and Type | Class and Description |
---|---|
class |
OggJsonFormatOptions
Option utils for ogg-json format.
|
Modifier and Type | Class and Description |
---|---|
class |
ParquetBulkWriter<T>
A simple
BulkWriter implementation that wraps a ParquetWriter . |
class |
ParquetWriterFactory<T>
A factory that creates a Parquet
BulkWriter . |
Modifier and Type | Class and Description |
---|---|
class |
RawFormatOptions
Options for the "raw" format.
|
Modifier and Type | Class and Description |
---|---|
class |
SequenceFileWriter<K extends org.apache.hadoop.io.Writable,V extends org.apache.hadoop.io.Writable>
A
BulkWriter implementation that wraps a SequenceFile.Writer . |
class |
SequenceFileWriterFactory<K extends org.apache.hadoop.io.Writable,V extends org.apache.hadoop.io.Writable>
A factory that creates a SequenceFile
BulkWriter . |
Modifier and Type | Class and Description |
---|---|
class |
S3RecoverableFsDataOutputStream
A RecoverableFsDataOutputStream to S3 that is based on a recoverable multipart upload.
|
class |
S3RecoverableWriter
An implementation of the
RecoverableWriter against S3. |
Modifier and Type | Class and Description |
---|---|
class |
KubernetesConfigOptions
This class holds configuration constants used by Flink's kubernetes runners.
|
class |
KubernetesHighAvailabilityOptions
The set of configuration options relating to Kubernetes high-availability settings.
|
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 | Interface and Description |
---|---|
interface |
OperatorCoordinatorMetricGroup
Special
MetricGroup representing an Operator coordinator. |
interface |
OperatorIOMetricGroup
Metric group that contains shareable pre-defined IO-related metrics for operators.
|
interface |
OperatorMetricGroup
Special
MetricGroup representing an Operator. |
interface |
SinkWriterMetricGroup
Pre-defined metrics for sinks.
|
interface |
SourceReaderMetricGroup
Pre-defined metrics for
SourceReader . |
interface |
SplitEnumeratorMetricGroup
Pre-defined metrics for
SplitEnumerator . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPrometheusReporter
base prometheus reporter for prometheus metrics.
|
class |
PrometheusPushGatewayReporter
|
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 |
Vectorizer<T>
This class provides an abstracted set of methods to handle the lifecycle of
VectorizedRowBatch . |
Modifier and Type | Class and Description |
---|---|
class |
OrcBulkWriterFactory<T>
A factory that creates an ORC
BulkWriter . |
Modifier and Type | Class and Description |
---|---|
class |
PythonOptions
Configuration options for the Python API.
|
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 |
RestoreMode
Defines how Flink should restore from a given savepoint or retained checkpoint.
|
class |
SavepointConfigOptions
The
configuration options used when restoring from a savepoint. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractStateBackend
An abstract base implementation of the
StateBackend interface. |
interface |
CheckpointStorage
CheckpointStorage defines how
StateBackend 's store their state for fault tolerance in
streaming applications. |
interface |
CheckpointStorageFactory<T extends CheckpointStorage>
A factory to create a specific
CheckpointStorage . |
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 locally within
the cluster.
|
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
Deprecated.
State backends should no longer implement
CheckpointStorage functionality.
Please inherit AbstractStateBackend instead. Custom checkpoint storage can be
additionally implemented as a separate class. |
class |
FsStateBackend
Deprecated.
|
class |
FsStateBackendFactory
A factory that creates an
FsStateBackend from a configuration. |
Modifier and Type | Class and Description |
---|---|
class |
HashMapStateBackend
This state backend holds the working state in the memory (JVM heap) of the TaskManagers and
checkpoints based on the configured
CheckpointStorage . |
class |
HashMapStateBackendFactory
A factory that creates an
HashMapStateBackend from a configuration. |
Modifier and Type | Class and Description |
---|---|
class |
MemoryStateBackend
Deprecated.
|
class |
MemoryStateBackendFactory
A factory that creates an
MemoryStateBackend from a configuration. |
Modifier and Type | Class and Description |
---|---|
class |
FileSystemCheckpointStorage
FileSystemCheckpointStorage checkpoints state as files to a file system. |
class |
JobManagerCheckpointStorage
The
CheckpointStorage checkpoints state directly to the JobManager's memory (hence the
name), but savepoints will be persisted to a file system. |
Modifier and Type | Class and Description |
---|---|
class |
BootstrapTransformation<T>
Deprecated.
Use
StateBootstrapTransformation instead. |
class |
EvictingWindowReader<W extends Window>
Deprecated.
|
class |
EvictingWindowSavepointReader<W extends Window>
This class provides entry points for reading keyed state written out using the
WindowOperator . |
class |
ExistingSavepoint
Deprecated.
For creating a new savepoint, use
SavepointWriter and the data stream api
under batch execution. For reading a savepoint, use SavepointReader and the data
stream api under batch execution. |
class |
KeyedOperatorTransformation<K,T>
Deprecated.
|
class |
KeyedStateTransformation<K,T>
A
KeyedStateTransformation represents a OneInputStateTransformation on which
operator state is partitioned by key using a provided KeySelector . |
class |
NewSavepoint
Deprecated.
For creating a new savepoint, use
SavepointWriter and the data stream api
under batch execution. |
class |
OneInputOperatorTransformation<T>
Deprecated.
Use
OneInputStateTransformation instead. |
class |
OneInputStateTransformation<T>
OneInputStateTransformation represents a user defined transformation applied on an OperatorTransformation with one input. |
class |
OperatorTransformation
This class provides the entry point for building
StateBootstrapTransformation s, which
represents procedures to bootstrap new operator states with a given DataStream . |
class |
Savepoint
Deprecated.
For creating a new savepoint, use
SavepointWriter and the data stream api
under batch execution. For reading a savepoint, use SavepointReader and the data
stream api under batch execution. |
class |
SavepointReader
The entry point for reading state from a Flink savepoint.
|
class |
SavepointWriter
A
SavepointWriter can create new savepoints from bounded data streams. |
interface |
SavepointWriterOperatorFactory
Creates a savepoint writing operator from a savepoint path.
|
class |
StateBootstrapTransformation<T>
A
StateBootstrapTransformation represents a procedure of writing new operator state into
a Savepoint . |
class |
WindowedOperatorTransformation<T,K,W extends Window>
A
WindowedOperatorTransformation represents a OneInputOperatorTransformation for
bootstrapping window state. |
class |
WindowedStateTransformation<T,K,W extends Window>
A
WindowedStateTransformation represents a OneInputStateTransformation for
bootstrapping window state. |
class |
WindowReader<W extends Window>
Deprecated.
|
class |
WindowSavepointReader<W extends Window>
This class provides entry points for reading keyed state written out using the
WindowOperator . |
class |
WritableSavepoint<F extends WritableSavepoint>
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
<ACC,R> StateBootstrapTransformation<T> |
WindowedStateTransformation.aggregate(AggregateFunction<T,ACC,R> function)
Applies the given aggregation function to each window.
|
<ACC,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,R> function)
Applies the given aggregation function to each window.
|
<ACC,R> StateBootstrapTransformation<T> |
WindowedStateTransformation.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType)
Applies the given aggregation function to each window.
|
<ACC,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType)
Applies the given aggregation function to each window.
|
<ACC,V,R> StateBootstrapTransformation<T> |
WindowedStateTransformation.aggregate(AggregateFunction<T,ACC,V> aggFunction,
ProcessWindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,V> aggFunction,
ProcessWindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> StateBootstrapTransformation<T> |
WindowedStateTransformation.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessWindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType)
Applies the given window function to each window.
|
<ACC,V,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessWindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType)
Applies the given window function to each window.
|
<ACC,V,R> StateBootstrapTransformation<T> |
WindowedStateTransformation.aggregate(AggregateFunction<T,ACC,V> aggFunction,
WindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,V> aggFunction,
WindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> StateBootstrapTransformation<T> |
WindowedStateTransformation.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
WindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType)
Applies the given window function to each window.
|
<ACC,V,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
WindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType)
Applies the given window function to each window.
|
WindowedStateTransformation<T,K,W> |
WindowedStateTransformation.evictor(Evictor<? super T,? super W> evictor)
Sets the
Evictor that should be used to evict elements from a window before emission. |
WindowedOperatorTransformation<T,K,W> |
WindowedOperatorTransformation.evictor(Evictor<? super T,? super W> evictor)
Sets the
Evictor that should be used to evict elements from a window before emission. |
<R> StateBootstrapTransformation<T> |
WindowedStateTransformation.process(ProcessWindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R> BootstrapTransformation<T> |
WindowedOperatorTransformation.process(ProcessWindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
OneInputOperatorTransformation<T> |
OneInputOperatorTransformation.setMaxParallelism(int maxParallelism)
Deprecated.
Sets the maximum parallelism of this operator.
|
OneInputStateTransformation<T> |
OneInputStateTransformation.setMaxParallelism(int maxParallelism)
Sets the maximum parallelism of this operator.
|
WindowedStateTransformation<T,K,W> |
WindowedStateTransformation.trigger(Trigger<? super T,? super W> trigger)
Sets the
Trigger that should be used to trigger window emission. |
WindowedOperatorTransformation<T,K,W> |
WindowedOperatorTransformation.trigger(Trigger<? super T,? super W> trigger)
Sets the
Trigger that should be used to trigger window emission. |
Modifier and Type | Class and Description |
---|---|
class |
BroadcastStateBootstrapFunction<IN>
Interface for writing elements to broadcast state.
|
class |
KeyedStateBootstrapFunction<K,IN>
A function that writes keyed state to a new operator.
|
class |
KeyedStateReaderFunction<K,OUT>
A function that processes keys from a restored operator
|
class |
StateBootstrapFunction<IN>
Interface for writing elements to operator state.
|
interface |
Timestamper<T>
Assigns an event time timestamp to the given record.
|
class |
WindowReaderFunction<IN,OUT,KEY,W extends Window>
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
Modifier and Type | Class and Description |
---|---|
class |
TimeCharacteristic
Deprecated.
In Flink 1.12 the default stream time characteristic has been changed to
TimeCharacteristic.EventTime , thus you don't need to call this method for enabling
event-time support anymore. Explicitly using processing-time windows and timers works in
event-time mode. If you need to disable watermarks, please use ExecutionConfig.setAutoWatermarkInterval(long) . If you are using TimeCharacteristic.IngestionTime , please manually set an appropriate WatermarkStrategy . If you are using generic "time window" operations (for example KeyedStream.timeWindow(org.apache.flink.streaming.api.windowing.time.Time)
that change behaviour based on the time characteristic, please use equivalent operations that
explicitly specify processing time or event time. |
interface |
TimerService
Interface for working with time and timers.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ExternallyInducedSource<T,CD>
Sources that implement this interface delay checkpoints when receiving a trigger message from the
checkpoint coordinator to the point when their input data/events indicate that a checkpoint
should be triggered.
|
interface |
ListCheckpointed<T extends Serializable>
Deprecated.
If you need to do non-keyed state snapshots of your operator, use
CheckpointedFunction . This should only be needed in rare cases, though. |
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 | 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 |
CustomSinkOperatorUidHashes
This class is responsible to hold operator Uid hashes from the common operators of the sink.
|
static class |
CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
Builder to construct
CustomSinkOperatorUidHashes . |
class |
IterativeStream<T>
The iterative data stream represents the start of an iteration in a
DataStream . |
static class |
KeyedStream.IntervalJoin<T1,T2,KEY>
Perform a join over a time interval.
|
static class |
KeyedStream.IntervalJoined<IN1,IN2,KEY>
IntervalJoined is a container for two streams that have keys for both sides as well as the
time boundaries over which elements should be joined.
|
class |
QueryableStateStream<K,V>
Queryable state stream instance.
|
class |
StreamProjection<IN>
The result of
DataStream.project(int...) . |
class |
UnsupportedTimeCharacteristicException
An exception that indicates that a time characteristic was used that is not supported in the
current operation.
|
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<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<R> resultType)
Applies the given window function to each window.
|
JoinedStreams.WithWindow<T1,T2,KEY,W> |
JoinedStreams.WithWindow.allowedLateness(Time newLateness)
Sets the time by which elements are allowed to be late.
|
AllWindowedStream<T,W> |
AllWindowedStream.allowedLateness(Time lateness)
Sets the time by which elements are allowed to be late.
|
CoGroupedStreams.WithWindow<T1,T2,KEY,W> |
CoGroupedStreams.WithWindow.allowedLateness(Time newLateness)
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.
|
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.
|
KeyedStream.IntervalJoined<T1,T2,KEY> |
KeyedStream.IntervalJoin.between(Time lowerBound,
Time upperBound)
Specifies the time boundaries over which the join operation works, so that
|
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 . |
DataStreamSink<T> |
DataStreamSink.disableChaining()
Turns off chaining for this operator so thread co-location will not be used as an
optimization.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.disableChaining()
Turns off chaining for this operator so thread co-location will not be used as an
optimization.
|
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. |
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. |
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. |
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. |
<T1> KeyedStream.IntervalJoin<T,T1,KEY> |
KeyedStream.intervalJoin(KeyedStream<T1,KEY> otherStream)
Join elements of this
KeyedStream with elements of another KeyedStream over a
time interval that can be specified with KeyedStream.IntervalJoin.between(Time, Time) . |
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.
|
KeyedStream.IntervalJoined<IN1,IN2,KEY> |
KeyedStream.IntervalJoined.lowerBoundExclusive()
Set the lower bound to be exclusive.
|
DataStreamSink<T> |
DataStream.print()
Writes a DataStream to the standard output stream (stdout).
|
DataStreamSink<T> |
DataStream.print(String sinkIdentifier)
Writes a DataStream to the standard output stream (stdout).
|
DataStreamSink<T> |
DataStream.printToErr()
Writes a DataStream to the standard error stream (stderr).
|
DataStreamSink<T> |
DataStream.printToErr(String sinkIdentifier)
Writes a DataStream to the standard error 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. |
<KEY,OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(KeyedBroadcastProcessFunction<KEY,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. |
<KEY,OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(KeyedBroadcastProcessFunction<KEY,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. |
<K,R> SingleOutputStreamOperator<R> |
ConnectedStreams.process(KeyedCoProcessFunction<K,IN1,IN2,R> keyedCoProcessFunction)
Applies the given
KeyedCoProcessFunction on the connected input keyed streams,
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.
|
<OUT> SingleOutputStreamOperator<OUT> |
KeyedStream.IntervalJoined.process(ProcessJoinFunction<IN1,IN2,OUT> processJoinFunction)
Completes the join operation with the given user function that is executed for each
joined pair of elements.
|
<OUT> SingleOutputStreamOperator<OUT> |
KeyedStream.IntervalJoined.process(ProcessJoinFunction<IN1,IN2,OUT> processJoinFunction,
TypeInformation<OUT> outputType)
Completes the join operation with the given user function that is executed for each
joined pair of elements.
|
<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. |
DataStreamSink<T> |
DataStreamSink.setDescription(String description)
Sets the description for this sink.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.setDescription(String description)
Sets the description for this operation.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.setMaxParallelism(int maxParallelism)
Sets the maximum parallelism of this operator.
|
DataStreamSink<T> |
DataStreamSink.setUidHash(String uidHash)
Sets an user provided hash for this operator.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.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 . |
DataStreamSink<T> |
DataStream.sinkTo(Sink<T,?,?,?> sink)
Adds the given
Sink to this DataStream. |
DataStreamSink<T> |
DataStream.sinkTo(Sink<T,?,?,?> sink,
CustomSinkOperatorUidHashes customSinkOperatorUidHashes)
Adds the given
Sink to this DataStream. |
DataStreamSink<T> |
DataStream.sinkTo(Sink<T> sink)
Adds the given
Sink to this DataStream. |
DataStreamSink<T> |
DataStream.sinkTo(Sink<T> sink,
CustomSinkOperatorUidHashes customSinkOperatorUidHashes)
Adds the given
Sink to this DataStream. |
DataStreamSink<T> |
DataStreamSink.slotSharingGroup(SlotSharingGroup slotSharingGroup)
Sets the slot sharing group of this operation.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.slotSharingGroup(SlotSharingGroup 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.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> |
DataStream.transform(String operatorName,
TypeInformation<R> outTypeInfo,
OneInputStreamOperatorFactory<T,R> operatorFactory)
Method for passing user defined operators created by the given factory along with the type
information that will transform the DataStream.
|
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.transform(String functionName,
TypeInformation<R> outTypeInfo,
TwoInputStreamOperator<IN1,IN2,R> operator) |
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.transform(String functionName,
TypeInformation<R> outTypeInfo,
TwoInputStreamOperatorFactory<IN1,IN2,R> operatorFactory) |
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. |
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. |
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. |
DataStreamSink<T> |
DataStreamSink.uid(String uid)
Sets an ID for this operator.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.uid(String uid)
Sets an ID for this operator.
|
KeyedStream.IntervalJoined<IN1,IN2,KEY> |
KeyedStream.IntervalJoined.upperBoundExclusive()
Set the upper bound to be exclusive.
|
<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> |
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> |
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
AllWindowedStream , which evaluates windows over a non
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)
Deprecated.
Please use the
StreamingFileSink explicitly
using the DataStream.addSink(SinkFunction) method. |
DataStreamSink<T> |
DataStream.writeAsCsv(String path,
FileSystem.WriteMode writeMode)
Deprecated.
Please use the
StreamingFileSink explicitly
using the DataStream.addSink(SinkFunction) method. |
<X extends Tuple> |
DataStream.writeAsCsv(String path,
FileSystem.WriteMode writeMode,
String rowDelimiter,
String fieldDelimiter)
Deprecated.
Please use the
StreamingFileSink explicitly
using the DataStream.addSink(SinkFunction) method. |
DataStreamSink<T> |
DataStream.writeAsText(String path)
Deprecated.
Please use the
StreamingFileSink explicitly
using the DataStream.addSink(SinkFunction) method. |
DataStreamSink<T> |
DataStream.writeAsText(String path,
FileSystem.WriteMode writeMode)
Deprecated.
Please use the
StreamingFileSink explicitly
using the DataStream.addSink(SinkFunction) method. |
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)
Deprecated.
Please use the
StreamingFileSink explicitly
using the DataStream.addSink(SinkFunction) method. |
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,
Time allowedLateness) |
Modifier and Type | Class and Description |
---|---|
static class |
CheckpointConfig.ExternalizedCheckpointCleanup
Cleanup behaviour for externalized checkpoints when the job is cancelled.
|
class |
ExecutionCheckpointingOptions
Execution
ConfigOption for configuring checkpointing related parameters. |
interface |
StreamExecutionEnvironmentFactory
Factory class for stream execution environments.
|
class |
StreamPipelineOptions
The
configuration options for job execution. |
Modifier and Type | Method and Description |
---|---|
void |
StreamExecutionEnvironment.clearJobListeners()
Clear all registered
JobListener s. |
void |
StreamExecutionEnvironment.configure(ReadableConfig configuration)
Sets all relevant options contained in the
ReadableConfig such as e.g. |
void |
StreamExecutionEnvironment.configure(ReadableConfig configuration,
ClassLoader classLoader)
Sets all relevant options contained in the
ReadableConfig such as e.g. |
<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.enableChangelogStateBackend(boolean enabled)
Enable the change log for current state backend.
|
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)
Deprecated.
|
void |
CheckpointConfig.enableUnalignedCheckpoints()
Enables unaligned checkpoints, which greatly reduce checkpointing times under backpressure.
|
void |
CheckpointConfig.enableUnalignedCheckpoints(boolean enabled)
Enables unaligned checkpoints, which greatly reduce checkpointing times under backpressure.
|
JobClient |
StreamExecutionEnvironment.executeAsync()
Triggers the program asynchronously.
|
JobClient |
StreamExecutionEnvironment.executeAsync(String jobName)
Triggers the program execution asynchronously.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromSource(Source<OUT,?,?> source,
WatermarkStrategy<OUT> timestampsAndWatermarks,
String sourceName)
Adds a data
Source to the environment to get a DataStream . |
java.time.Duration |
CheckpointConfig.getAlignedCheckpointTimeout() |
java.time.Duration |
CheckpointConfig.getAlignmentTimeout()
Deprecated.
User
CheckpointConfig.getAlignedCheckpointTimeout() instead. |
long |
CheckpointConfig.getCheckpointIdOfIgnoredInFlightData() |
CheckpointStorage |
CheckpointConfig.getCheckpointStorage() |
static int |
StreamExecutionEnvironment.getDefaultLocalParallelism()
Gets the default parallelism that will be used for the local execution environment created by
StreamExecutionEnvironment.createLocalEnvironment() . |
Path |
StreamExecutionEnvironment.getDefaultSavepointDirectory()
Gets the default savepoint directory for this Job.
|
CheckpointConfig.ExternalizedCheckpointCleanup |
CheckpointConfig.getExternalizedCheckpointCleanup()
Returns the cleanup behaviour for externalized checkpoints.
|
List<JobListener> |
StreamExecutionEnvironment.getJobListeners()
Gets the config JobListeners.
|
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()
Deprecated.
See
StreamExecutionEnvironment.setStreamTimeCharacteristic(TimeCharacteristic) for deprecation
notice. |
boolean |
StreamExecutionEnvironment.isChainingEnabled()
Returns whether operator chaining is enabled.
|
TernaryBoolean |
StreamExecutionEnvironment.isChangelogStateBackendEnabled()
Gets the enable status of change log for state backend.
|
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.
|
boolean |
CheckpointConfig.isForceUnalignedCheckpoints()
Checks whether unaligned checkpoints are forced, despite iteration feedback.
|
boolean |
StreamExecutionEnvironment.isForceUnalignedCheckpoints()
Returns whether unaligned checkpoints are force-enabled.
|
boolean |
CheckpointConfig.isUnalignedCheckpointsEnabled()
Returns whether unaligned checkpoints are enabled.
|
boolean |
StreamExecutionEnvironment.isUnalignedCheckpointsEnabled()
Returns whether unaligned checkpoints are enabled.
|
<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 . |
void |
StreamExecutionEnvironment.registerJobListener(JobListener jobListener)
Register a
JobListener in this environment. |
StreamExecutionEnvironment |
StreamExecutionEnvironment.registerSlotSharingGroup(SlotSharingGroup slotSharingGroup)
Register a slot sharing group with its resource spec.
|
void |
CheckpointConfig.setAlignedCheckpointTimeout(java.time.Duration alignedCheckpointTimeout)
Only relevant if
CheckpointConfig.unalignedCheckpointsEnabled is enabled. |
void |
CheckpointConfig.setAlignmentTimeout(java.time.Duration alignmentTimeout)
Deprecated.
|
void |
CheckpointConfig.setCheckpointIdOfIgnoredInFlightData(long checkpointIdOfIgnoredInFlightData)
Setup the checkpoint id for which the in-flight data will be ignored for all operators in
case of the recovery from this checkpoint.
|
void |
CheckpointConfig.setCheckpointStorage(CheckpointStorage storage)
CheckpointStorage defines how
StateBackend 's checkpoint their state for fault
tolerance in streaming applications. |
void |
CheckpointConfig.setCheckpointStorage(Path checkpointDirectory)
Configures the application to write out checkpoint snapshots to the configured directory.
|
void |
CheckpointConfig.setCheckpointStorage(String checkpointDirectory)
Configures the application to write out checkpoint snapshots to the configured directory.
|
void |
CheckpointConfig.setCheckpointStorage(URI checkpointDirectory)
Configures the application to write out checkpoint snapshots to the configured directory.
|
static void |
StreamExecutionEnvironment.setDefaultLocalParallelism(int parallelism)
Sets the default parallelism that will be used for the local execution environment created by
StreamExecutionEnvironment.createLocalEnvironment() . |
StreamExecutionEnvironment |
StreamExecutionEnvironment.setDefaultSavepointDirectory(Path savepointDirectory)
Sets the default savepoint directory, where savepoints will be written to if no is explicitly
provided when triggered.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setDefaultSavepointDirectory(String savepointDirectory)
Sets the default savepoint directory, where savepoints will be written to if no is explicitly
provided when triggered.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setDefaultSavepointDirectory(URI savepointDirectory)
Sets the default savepoint directory, where savepoints will be written to if no is explicitly
provided when triggered.
|
void |
CheckpointConfig.setExternalizedCheckpointCleanup(CheckpointConfig.ExternalizedCheckpointCleanup cleanupMode)
Sets the mode for externalized checkpoint clean-up.
|
void |
CheckpointConfig.setForceCheckpointing(boolean forceCheckpointing)
Deprecated.
This will be removed once iterations properly participate in checkpointing.
|
void |
CheckpointConfig.setForceUnalignedCheckpoints(boolean forceUnalignedCheckpoints)
Checks whether unaligned checkpoints are forced, despite currently non-checkpointable
iteration feedback or custom partitioners.
|
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.setRuntimeMode(RuntimeExecutionMode executionMode)
Sets the runtime execution mode for the application (see
RuntimeExecutionMode ). |
StreamExecutionEnvironment |
StreamExecutionEnvironment.setStateBackend(StateBackend backend)
Sets the state backend that describes how to store operator.
|
void |
StreamExecutionEnvironment.setStreamTimeCharacteristic(TimeCharacteristic characteristic)
Deprecated.
In Flink 1.12 the default stream time characteristic has been changed to
TimeCharacteristic.EventTime , thus you don't need to call this method for enabling
event-time support anymore. Explicitly using processing-time windows and timers works in
event-time mode. If you need to disable watermarks, please use ExecutionConfig.setAutoWatermarkInterval(long) . If you are using TimeCharacteristic.IngestionTime , please manually set an appropriate WatermarkStrategy . If you are using generic "time window" operations (for example KeyedStream.timeWindow(org.apache.flink.streaming.api.windowing.time.Time)
that change behaviour based on the time characteristic, please use equivalent operations
that explicitly specify processing time or event 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.
|
Constructor and Description |
---|
RemoteStreamEnvironment(PipelineExecutorServiceLoader executorServiceLoader,
String host,
int port,
Configuration clientConfiguration,
String[] jarFiles,
URL[] globalClasspaths,
SavepointRestoreSettings savepointRestoreSettings) |
RemoteStreamEnvironment(String host,
int port,
Configuration clientConfiguration,
String[] jarFiles,
URL[] globalClasspaths,
SavepointRestoreSettings savepointRestoreSettings)
Creates a new RemoteStreamEnvironment that points to the master (JobManager) described by the
given host name and port.
|
StreamExecutionEnvironment(Configuration configuration)
Creates a new
StreamExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor . |
StreamExecutionEnvironment(Configuration configuration,
ClassLoader userClassloader)
Creates a new
StreamExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor . |
StreamExecutionEnvironment(PipelineExecutorServiceLoader executorServiceLoader,
Configuration configuration,
ClassLoader userClassloader)
Creates a new
StreamExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor . |
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. |
class |
KeyedCoProcessFunction<K,IN1,IN2,OUT>
A function that processes elements of two keyed streams and produces a single output one.
|
class |
ProcessJoinFunction<IN1,IN2,OUT>
A function that processes two joined elements and produces a single output one.
|
Modifier and Type | Class and Description |
---|---|
class |
OutputFormatSinkFunction<IN>
Deprecated.
Please use the
StreamingFileSink
for writing to files from a streaming program. |
class |
PrintSinkFunction<IN>
Implementation of the SinkFunction writing every tuple to the standard output or standard error
stream.
|
class |
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
StreamingFileSink
for writing to files from a streaming program. |
class |
WriteFormatAsCsv<IN>
Deprecated.
Please use the
StreamingFileSink
for writing to files from a streaming program. |
class |
WriteFormatAsText<IN>
Deprecated.
Please use the
StreamingFileSink
for writing to files from a streaming program. |
class |
WriteSinkFunction<IN>
Deprecated.
Please use the
StreamingFileSink
for writing to files from a streaming program. |
class |
WriteSinkFunctionByMillis<IN>
Deprecated.
Please use the
StreamingFileSink
for writing to files from a streaming program. |
Modifier and Type | Interface and Description |
---|---|
interface |
BucketAssigner<IN,BucketID>
A BucketAssigner is used with a file sink to determine the bucket each incoming element should be
put into.
|
static interface |
BucketAssigner.Context
Context that the
BucketAssigner can use for getting additional data about an input
record. |
static class |
OutputFileConfig.OutputFileConfigBuilder
A builder to create the part file configuration.
|
interface |
PartFileInfo<BucketID>
An interface exposing the information concerning the current (open) part file that is necessary
to the
RollingPolicy in order to determine if it should roll the part file or not. |
interface |
RollingPolicy<IN,BucketID>
The policy based on which a
Bucket in the Filesystem Sink rolls its currently
open part file and opens a new one. |
class |
StreamingFileSink<IN>
Sink that emits its input elements to
FileSystem files within buckets. |
static class |
StreamingFileSink.BulkFormatBuilder<IN,BucketID,T extends StreamingFileSink.BulkFormatBuilder<IN,BucketID,T>>
A builder for configuring the sink for bulk-encoding formats, e.g.
|
static class |
StreamingFileSink.RowFormatBuilder<IN,BucketID,T extends StreamingFileSink.RowFormatBuilder<IN,BucketID,T>>
A builder for configuring the sink for row-wise encoding formats.
|
Modifier and Type | Class and Description |
---|---|
class |
BasePathBucketAssigner<T>
A
BucketAssigner that does not perform any bucketing of files. |
class |
DateTimeBucketAssigner<IN>
A
BucketAssigner that assigns to buckets based on current system time. |
class |
SimpleVersionedStringSerializer
A
SimpleVersionedSerializer implementation for Strings. |
Modifier and Type | Class and Description |
---|---|
class |
CheckpointRollingPolicy<IN,BucketID>
An abstract
RollingPolicy which rolls on every checkpoint. |
class |
DefaultRollingPolicy<IN,BucketID>
The default implementation of the
RollingPolicy . |
static class |
DefaultRollingPolicy.PolicyBuilder
A helper class that holds the configuration properties for the
DefaultRollingPolicy . |
class |
OnCheckpointRollingPolicy<IN,BucketID>
A
RollingPolicy which rolls (ONLY) on every checkpoint. |
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>
Deprecated.
|
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.
|
interface |
BoundedMultiInput
Interface for multi-input operators that need to be notified about the logical/semantical end of
input.
|
interface |
BoundedOneInput
Interface for one-input operators that need to be notified about the logical/semantical end of
input.
|
class |
ChainingStrategy
Defines the chaining scheme for the operator.
|
interface |
Input<IN>
Input interface used in MultipleInputStreamOperator . |
interface |
InputSelectable
Interface for stream operators that can select the input to get
StreamRecord . |
class |
InputSelection
Describe the input selection that stream operators want to read records.
|
interface |
MultipleInputStreamOperator<OUT>
Interface for stream operators with multiple
Input s. |
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 |
SetupableStreamOperator<OUT>
Deprecated.
This class is deprecated in favour of using
StreamOperatorFactory and it's
StreamOperatorFactory.createStreamOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<OUT>) and passing the required parameters to the
Operator's constructor in create method. |
interface |
StreamOperator<OUT>
Basic interface for stream operators.
|
interface |
StreamOperatorFactory<OUT>
A factory to create
StreamOperator . |
interface |
TwoInputStreamOperator<IN1,IN2,OUT>
Interface for stream operators with two inputs.
|
interface |
TwoInputStreamOperatorFactory<IN1,IN2,OUT>
A factory to create
TwoInputStreamOperator . |
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 |
SlidingEventTimeWindows
A
WindowAssigner that windows elements into sliding windows based on the timestamp of the
elements. |
class |
TumblingEventTimeWindows
A
WindowAssigner that windows elements into windows based on the timestamp of the
elements. |
class |
WindowAssigner<T,W extends Window>
A
WindowAssigner assigns zero or more Windows to an element. |
class |
WindowStagger
A
WindowStagger staggers offset in runtime for each window assignment. |
Modifier and Type | Method and Description |
---|---|
static TumblingProcessingTimeWindows |
TumblingProcessingTimeWindows.of(Time size,
Time offset,
WindowStagger windowStagger)
Creates a new
TumblingProcessingTimeWindows WindowAssigner that assigns
elements to time windows based on the element timestamp, offset and a staggering offset,
depending on the staggering policy. |
static TumblingEventTimeWindows |
TumblingEventTimeWindows.of(Time size,
Time offset,
WindowStagger windowStagger)
Creates a new
TumblingEventTimeWindows WindowAssigner that assigns elements
to time windows based on the element timestamp, offset and a staggering offset, depending on
the staggering policy. |
static <T> DynamicEventTimeSessionWindows<T> |
EventTimeSessionWindows.withDynamicGap(SessionWindowTimeGapExtractor<T> sessionWindowTimeGapExtractor)
Creates a new
SessionWindows WindowAssigner that assigns elements to sessions
based on the element timestamp. |
static <T> DynamicProcessingTimeSessionWindows<T> |
ProcessingTimeSessionWindows.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 |
ProcessingTimeoutTrigger<T,W extends Window>
|
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 | Interface and Description |
---|---|
interface |
CassandraFailureHandler
An implementation of
CassandraFailureHandler is provided by the user to define how Throwable should be handled, e.g. |
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
Deprecated.
This has been deprecated and will be removed in the future.
|
static class |
ElasticsearchSinkBase.FlushBackoffType
Used to control whether the retry delay should increase exponentially or remain constant.
|
interface |
ElasticsearchSinkFunction<T>
Deprecated.
This has been deprecated and will be removed in the future.
|
interface |
RequestIndexer
Deprecated.
This has been deprecated and will be removed in the future.
|
Modifier and Type | Class and Description |
---|---|
class |
ElasticsearchConnectorOptions
Options for the Elasticsearch connector.
|
Modifier and Type | Class and Description |
---|---|
class |
RetryRejectedExecutionFailureHandler
Deprecated.
This hase been deprecated and will be removed in the future.
|