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 | 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 |
---|---|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromSource(Source<OUT,?,?> source,
WatermarkStrategy<OUT> timestampsAndWatermarks,
String sourceName)
Add 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)
Add a data
Source to the environment to get a DataStream . |
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) . |
void |
TableEnvironment.createFunction(String path,
Class<? extends UserDefinedFunction> functionClass)
Registers a
UserDefinedFunction class as a catalog function in the given path. |
void |
TableEnvironment.createFunction(String path,
Class<? extends UserDefinedFunction> functionClass,
boolean ignoreIfExists)
Registers a
UserDefinedFunction class as a catalog function in the given path. |
void |
TableEnvironment.createTemporaryFunction(String path,
Class<? extends UserDefinedFunction> functionClass)
Registers a
UserDefinedFunction class as a temporary catalog function. |
void |
TableEnvironment.createTemporaryFunction(String path,
UserDefinedFunction functionInstance)
Registers a
UserDefinedFunction instance as a temporary catalog function. |
void |
TableEnvironment.createTemporarySystemFunction(String name,
Class<? extends UserDefinedFunction> functionClass)
Registers a
UserDefinedFunction class as a temporary system function. |
void |
TableEnvironment.createTemporarySystemFunction(String name,
UserDefinedFunction functionInstance)
Registers a
UserDefinedFunction instance as a temporary system function. |
boolean |
TableEnvironment.dropFunction(String path)
Drops a catalog function registered in the given path.
|
boolean |
TableEnvironment.dropTemporaryFunction(String path)
Drops a temporary catalog function registered in the given path.
|
boolean |
TableEnvironment.dropTemporarySystemFunction(String name)
Drops a temporary system function registered under the given name.
|
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>
|
interface |
OverwritableTableSink
A
TableSink that supports INSERT OVERWRITE should implement this trait. |
interface |
PartitionableTableSink
An interface for partitionable
TableSink . |
Modifier and Type | Class and Description |
---|---|
class |
InputFormatTableSource<T>
Defines an external bounded table and provides access to its data.
|
interface |
LimitableTableSource<T>
Adds support for limiting push-down to a
TableSource . |
interface |
LookupableTableSource<T>
A
TableSource which supports for lookup accessing via key column(s). |
interface |
PartitionableTableSource
An interface for partitionable
TableSource . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.