Modifier and Type | Interface and Description |
---|---|
interface |
Committer<CommT>
The
Committer is responsible for committing the data staged by the sink. |
interface |
GlobalCommitter<CommT,GlobalCommT>
The
GlobalCommitter is responsible for creating and committing an aggregated committable,
which we call global committable (see GlobalCommitter.combine(java.util.List<CommT>) ). |
interface |
Sink<InputT,CommT,WriterStateT,GlobalCommT>
This interface lets the sink developer build a simple sink topology, which could guarantee the
exactly once semantics in both batch and stream execution mode if there is a
Committer or
GlobalCommitter . |
interface |
SinkWriter<InputT,CommT,WriterStateT>
The
SinkWriter is responsible for writing data and handling any potential tmp area used
to write yet un-staged data, e.g. |
Modifier and Type | Interface and Description |
---|---|
interface |
ExternallyInducedSourceReader<T,SplitT extends SourceSplit>
Sources that implement this interface do not trigger checkpoints when receiving a trigger message
from the checkpoint coordinator, but when their input data/events indicate that a checkpoint
should be triggered.
|
Modifier and Type | Class and Description |
---|---|
class |
FileSink<IN>
A unified sink that emits its input elements to
FileSystem files within buckets. |
Modifier and Type | Class and Description |
---|---|
class |
HBaseInputFormat<T extends Tuple>
InputFormat subclass that wraps the access for HTables. |
Modifier and Type | Class and Description |
---|---|
class |
HBaseInputFormat<T extends Tuple>
InputFormat subclass that wraps the access for HTables. |
Modifier and Type | Class and Description |
---|---|
class |
JdbcInputFormat
InputFormat to read data from a database and generate Rows.
|
class |
JdbcOutputFormat
OutputFormat to write Rows into a JDBC database.
|
Modifier and Type | Class and Description |
---|---|
class |
JdbcGenericParameterValuesProvider
This splits generator actually does nothing but wrapping the query parameters computed by the
user before creating the
JdbcInputFormat instance. |
class |
JdbcNumericBetweenParametersProvider
This query parameters generator is an helper class to parameterize from/to queries on a numeric
column.
|
interface |
JdbcParameterValuesProvider
This interface is used by the
JdbcInputFormat to compute the list of parallel query to
run (i.e. |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Integer> |
PythonOptions.MAP_STATE_ITERATE_RESPONSE_BATCH_SIZE
The maximum number of entries sent to Python UDF worker per request when iterating a Python
MapState.
|
static ConfigOption<Integer> |
PythonOptions.MAP_STATE_READ_CACHE_SIZE
The maximum number of cached items which read from Java side in a Python MapState.
|
static ConfigOption<Integer> |
PythonOptions.MAP_STATE_WRITE_CACHE_SIZE
The maximum number of write requests cached in a Python MapState.
|
static ConfigOption<Integer> |
PythonOptions.STATE_CACHE_SIZE
The maximum number of states cached in a Python UDF worker.
|
Modifier and Type | Class and Description |
---|---|
class |
DataStreamUtils
A collection of utilities for
DataStreams . |
class |
MultipleConnectedStreams
This is a very basic and rough stub for a class connecting multiple input
DataStream s
into one, using MultipleInputStreamOperator . |
Modifier and Type | Method and Description |
---|---|
DataStreamSink<T> |
DataStream.sinkTo(Sink<T,?,?,?> sink)
Adds the given
Sink to this DataStream. |
Modifier and Type | Method and Description |
---|---|
void |
CheckpointConfig.enableApproximateLocalRecovery(boolean enabled)
Enables the approximate local recovery mode.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromSource(Source<OUT,?,?> source,
WatermarkStrategy<OUT> timestampsAndWatermarks,
String sourceName)
Adds a data
Source to the environment to get a DataStream . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromSource(Source<OUT,?,?> source,
WatermarkStrategy<OUT> timestampsAndWatermarks,
String sourceName,
TypeInformation<OUT> typeInfo)
Adds a data
Source to the environment to get a DataStream . |
boolean |
CheckpointConfig.isApproximateLocalRecoveryEnabled()
Returns whether approximate local recovery is enabled.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DataGenerator<T>
Stateful and re-scalable data generator.
|
class |
DataGeneratorSource<T>
A data generator source that abstract data generator.
|
class |
RandomGenerator<T>
Random generator.
|
class |
SequenceGenerator<T>
A stateful, re-scalable
DataGenerator that emits each number from a given interval
exactly once, possibly in parallel. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractInput<IN,OUT>
Base abstract implementation of
Input interface intended to be used when extending AbstractStreamOperatorV2 . |
class |
AbstractStreamOperatorFactory<OUT>
Base class for all stream operator factories.
|
class |
AbstractStreamOperatorV2<OUT>
New base class for all stream operators, intended to eventually replace
AbstractStreamOperator . |
interface |
StreamOperatorFactory<OUT>
A factory to create
StreamOperator . |
class |
StreamOperatorParameters<OUT>
Helper class to construct
AbstractStreamOperatorV2 . |
interface |
YieldingOperatorFactory<OUT>
An operator that needs access to the
MailboxExecutor to yield to downstream operators
needs to be created through a factory implementing this interface. |
Modifier and Type | Class and Description |
---|---|
class |
FlinkKafkaShuffle
FlinkKafkaShuffle uses Kafka as a message bus to shuffle and persist data at the same
time. |
Modifier and Type | Class and Description |
---|---|
class |
CollectSink<IN>
A specialized data sink to be used by DataStreamUtils.collect().
|
class |
SocketStreamIterator<T>
An iterator that returns the data from a socket stream.
|
Modifier and Type | Method and Description |
---|---|
void |
TableConfig.addJobParameter(String key,
String value)
Sets a custom user parameter that can be accessed via
FunctionContext.getJobParameter(String, String) . |
Modifier and Type | Interface and Description |
---|---|
interface |
LookupTableSource
A
DynamicTableSource that looks up rows of an external storage system by one or more keys
during runtime. |
Modifier and Type | Interface and Description |
---|---|
interface |
PartitionCommitPolicy
Policy for commit a partition.
|
interface |
PartitionTimeExtractor
Time extractor to extract time from partition values.
|
Modifier and Type | Class and Description |
---|---|
class |
AsyncTableFunction<T>
Base class for a user-defined asynchronously table function (UDTF).
|
Modifier and Type | Class and Description |
---|---|
class |
OutputFormatTableSink<T>
Deprecated.
This interface has been replaced by
DynamicTableSink . The new interface
consumes internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
interface |
OverwritableTableSink
Deprecated.
This interface will not be supported in the new sink design around
DynamicTableSink which only works with the Blink planner. Use SupportsOverwrite
instead. See FLIP-95 for more information. |
interface |
PartitionableTableSink
Deprecated.
This interface will not be supported in the new sink design around
DynamicTableSink which only works with the Blink planner. Use SupportsPartitioning
instead. See FLIP-95 for more information. |
Modifier and Type | Class and Description |
---|---|
class |
InputFormatTableSource<T>
Deprecated.
This interface has been replaced by
DynamicTableSource . The new interface
produces internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
interface |
LimitableTableSource<T>
Deprecated.
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use SupportsLimitPushDown instead. See FLIP-95 for more information. |
interface |
LookupableTableSource<T>
Deprecated.
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use LookupTableSource
instead. See FLIP-95 for more information. |
interface |
PartitionableTableSource
Deprecated.
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use SupportsPartitionPushDown instead. See FLIP-95 for more information. |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.