Modifier and Type | Class and Description |
---|---|
class |
SlotSharingGroup
Describe the name and the different resource components of a slot sharing group.
|
static class |
SlotSharingGroup.Builder
Builder for
SlotSharingGroup . |
Modifier and Type | Method and Description |
---|---|
int |
ExecutionConfig.getAsyncInflightRecordsLimit() |
int |
ExecutionConfig.getAsyncStateBufferSize() |
long |
ExecutionConfig.getAsyncStateBufferTimeout() |
ExecutionConfig |
ExecutionConfig.setAsyncInflightRecordsLimit(int limit) |
ExecutionConfig |
ExecutionConfig.setAsyncStateBufferSize(int bufferSize) |
ExecutionConfig |
ExecutionConfig.setAsyncStateBufferTimeout(long timeout) |
Modifier and Type | Class and Description |
---|---|
class |
OutputFormatBase<OUT,V>
OutputFormatBase is the common abstract class for output formats.
|
class |
SinkUtils
Utility class for sinks.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AggregatingStateDeclaration<IN,ACC,OUT>
This represents a declaration of the aggregating state.
|
interface |
BroadcastStateDeclaration<K,V>
This represents a declaration of the broadcast state.
|
class |
IllegalRedistributionModeException
A special
IllegalStateException indicating a mismatch in StateDeclaration . |
interface |
ListStateDeclaration<T>
This represents a declaration of the list state.
|
static class |
ListStateDeclaration.RedistributionStrategy
ListStateDeclaration.RedistributionStrategy is used to guide the assignment of states during rescaling. |
interface |
MapStateDeclaration<K,V>
This represents a declaration of the map state.
|
interface |
ReducingStateDeclaration<T>
This represents a declaration of the reducing state.
|
interface |
StateDeclaration
StateDeclaration represents a declaration of the specific state used. |
static class |
StateDeclaration.RedistributionMode
StateDeclaration.RedistributionMode is used to indicate whether this state supports redistribution
between partitions and how to redistribute this state during rescaling. |
class |
StateDeclarations
This is a helper class for declaring various states.
|
static class |
StateDeclarations.AggregatingStateDeclarationBuilder<IN,OUT,ACC>
Builder for
AggregatingStateDeclaration . |
static class |
StateDeclarations.ListStateDeclarationBuilder<T>
Builder for
ListStateDeclaration . |
static class |
StateDeclarations.MapStateDeclarationBuilder<K,V>
Builder for
MapStateDeclaration . |
static class |
StateDeclarations.ReducingStateDeclarationBuilder<T>
Builder for
ReducingStateDeclaration . |
static class |
StateDeclarations.ValueStateDeclarationBuilder<T>
Builder for
ValueStateDeclaration . |
interface |
ValueStateDeclaration<T>
This represents a declaration of the value state.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AggregatingState<IN,OUT>
State interface for aggregating state, based on an AggregateFunction . |
interface |
AppendingState<IN,OUT>
Base interface for partitioned state that supports adding elements and inspecting the current
state.
|
interface |
ListState<T>
State interface for partitioned list state in Operations. |
interface |
MapState<UK,UV>
State interface for partitioned key-value state. |
interface |
MergingState<IN,OUT>
Extension of
AppendingState that allows merging of state. |
interface |
ReducingState<T>
State interface for reducing state. |
interface |
State
Interface that different types of partitioned state must implement.
|
interface |
StateFuture<T>
StateFuture is a future that act as a return value for async state interfaces.
|
interface |
StateIterator<T>
Asynchronous iterators allow to iterate over data that comes asynchronously, on-demand.
|
interface |
ValueState<T>
State interface for partitioned single-value state. |
Modifier and Type | Interface and Description |
---|---|
interface |
TypeDescriptor<T>
Descriptor interface to create TypeInformation instances.
|
class |
TypeDescriptors
Descriptor interface to create TypeInformation instances.
|
Modifier and Type | Class and Description |
---|---|
class |
TypeUtils
Utility class to create objects via reflection.
|
Modifier and Type | Class and Description |
---|---|
class |
DataStreamV2SinkUtils
Utils to create the DataStream V2 supported
Sink . |
class |
DataStreamV2SourceUtils
Utils to create the DataStream V2 supported
Source . |
interface |
Sink<T>
Sink interface for DataStream api v2.
|
interface |
Source<T>
Source interface for DataStream api v2.
|
Modifier and Type | Method and Description |
---|---|
default <MetaT> Optional<Consumer<MetaT>> |
Sink.InitContext.metadataConsumer()
Deprecated.
Returns a metadata consumer, the
SinkWriter can publish metadata events of type
MetaT to the consumer. |
<MetaT> Optional<Consumer<MetaT>> |
Sink.InitContextWrapper.metadataConsumer()
Deprecated.
|
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 |
RateLimitedSourceReader<E,SplitT extends SourceSplit>
Wraps the actual
SourceReader and rate limits its data emission. |
interface |
RateLimiter
The interface to rate limit execution of methods.
|
interface |
RateLimiterStrategy
A factory for
RateLimiters which apply rate-limiting to a source sub-task. |
Modifier and Type | Class and Description |
---|---|
class |
FsStateChangelogOptions
|
class |
FsStateChangelogStorage
Filesystem-based implementation of
StateChangelogStorage . |
class |
FsStateChangelogStorageForRecovery
Filesystem-based implementation of
StateChangelogStorage just for recovery. |
Modifier and Type | Class and Description |
---|---|
class |
SchedulerExecutionMode
Enum for controlling whether REACTIVE mode is enabled or not.
|
class |
TraceOptions
Configuration options for traces and trace reporters.
|
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Integer> |
ExecutionOptions.ASYNC_INFLIGHT_RECORDS_LIMIT
The max limit of in-flight records number in async state execution, 'in-flight' refers to the
records that have entered the operator but have not yet been processed and emitted to the
downstream.
|
static ConfigOption<Integer> |
ExecutionOptions.ASYNC_STATE_BUFFER_SIZE
The size of buffer under async state execution.
|
static ConfigOption<Long> |
ExecutionOptions.ASYNC_STATE_BUFFER_TIMEOUT
The timeout of buffer triggering in milliseconds.
|
static ConfigOption<Boolean> |
CheckpointingOptions.ENABLE_UNALIGNED_INTERRUPTIBLE_TIMERS |
static ConfigOption<Boolean> |
CheckpointingOptions.FILE_MERGING_ACROSS_BOUNDARY
Whether to allow merging data of multiple checkpoints into one physical file.
|
static ConfigOption<Boolean> |
CheckpointingOptions.FILE_MERGING_ENABLED
Whether to enable merging multiple checkpoint files into one, which will greatly reduce the
number of small checkpoint files.
|
static ConfigOption<MemorySize> |
CheckpointingOptions.FILE_MERGING_MAX_FILE_SIZE
The max size of a physical file for merged checkpoints.
|
static ConfigOption<Float> |
CheckpointingOptions.FILE_MERGING_MAX_SPACE_AMPLIFICATION
Space amplification stands for the magnification of the occupied space compared to the amount
of valid data.
|
static ConfigOption<Integer> |
CheckpointingOptions.FILE_MERGING_MAX_SUBTASKS_PER_FILE
The upper limit of the file pool size based on the number of subtasks within each TM (only
for merging private state at Task Manager level).
|
static ConfigOption<Boolean> |
CheckpointingOptions.FILE_MERGING_POOL_BLOCKING
Whether to use Blocking or Non-Blocking pool for merging physical files.
|
static ConfigOption<Boolean> |
NettyShuffleEnvironmentOptions.NETWORK_HYBRID_SHUFFLE_ENABLE_NEW_MODE
Deprecated.
This option is deprecated in 1.20 and will be totally removed in 2.0, as the
legacy hybrid shuffle mode will be removed in 2.0.
|
static ConfigOption<String> |
NettyShuffleEnvironmentOptions.NETWORK_HYBRID_SHUFFLE_EXTERNAL_REMOTE_TIER_FACTORY_CLASS_NAME
The option to configure the tiered factory creator remote class name for hybrid shuffle.
|
static ConfigOption<String> |
NettyShuffleEnvironmentOptions.NETWORK_HYBRID_SHUFFLE_REMOTE_STORAGE_BASE_PATH
The option to configure the base remote storage path for hybrid shuffle.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NETWORK_READ_MAX_REQUIRED_BUFFERS_PER_GATE
The maximum number of network read buffers that are required by an input gate.
|
static ConfigOption<Boolean> |
DeploymentOptions.PROGRAM_CONFIG_ENABLED |
static ConfigOption<List<String>> |
DeploymentOptions.PROGRAM_CONFIG_WILDCARDS |
static ConfigOption<Boolean> |
DeploymentOptions.SUBMIT_FAILED_JOB_ON_APPLICATION_ERROR |
Modifier and Type | Method and Description |
---|---|
static Configuration |
SecurityOptions.forProvider(Configuration configuration,
String providerName)
Returns a view over the given configuration via which options can be set/retrieved for the
given provider.
|
static Configuration |
MetricOptions.forReporter(Configuration configuration,
String reporterName)
Returns a view over the given configuration via which options can be set/retrieved for the
given reporter.
|
static Configuration |
TraceOptions.forTraceReporter(Configuration configuration,
String reporterName)
Returns a view over the given configuration via which options can be set/retrieved for the
given reporter.
|
Modifier and Type | Class and Description |
---|---|
class |
DataGeneratorSource<OUT>
A data source that produces N data points in parallel.
|
class |
DoubleEmittingSourceReaderWithCheckpointsInBetween<E,O,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>>
A
SourceReader that synchronizes emission of N elements on the arrival of the checkpoint
barriers It 1) emits a list of elements without checkpoints in-between, 2) then waits for two
checkpoints to complete, 3) then re-emits the same elements before 4) waiting for another two
checkpoints and 5) exiting. |
class |
GeneratingIteratorSourceReader<E,O,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>>
A
SourceReader that takes the values of an iterator, supplied via an IteratorSourceSplit , and applies a GeneratorFunction to them to perform arbitrary
transformations. |
interface |
GeneratorFunction<T,O>
Base interface for data generator functions.
|
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 | Interface and Description |
---|---|
interface |
PartitionCommitPolicy
Policy for commit a partition.
|
interface |
PartitionTimeExtractor
Time extractor to extract time from partition values.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TestResource
Basic abstractions for all resources used in connector testing framework, including
TestEnvironment annotated by TestEnv and external system annotated by TestExternalSystem . |
Modifier and Type | Interface and Description |
---|---|
interface |
ClusterControllable
Interface for triggering failover in a Flink cluster.
|
class |
MiniClusterTestEnvironment
Test environment for running jobs on Flink mini-cluster.
|
interface |
TestEnvironment
Test environment for running Flink jobs.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultContainerizedExternalSystem<C extends org.testcontainers.containers.GenericContainer<C>>
Default implementation of external system based on container.
|
interface |
ExternalContext
External context for interacting with external system in testing framework.
|
interface |
ExternalContextFactory<C extends ExternalContext>
Factory for creating
ExternalContext . |
interface |
ExternalSystemDataReader<T>
A data reader for consuming records from an external system.
|
interface |
ExternalSystemSplitDataWriter<T>
A data writer for writing records into a
SourceSplit in the external system. |
Modifier and Type | Interface and Description |
---|---|
interface |
DataStreamSinkExternalContext<T>
External context for DataStream sinks.
|
interface |
DataStreamSinkV1ExternalContext<T>
External context for DataStream sinks whose version is V1.
|
interface |
DataStreamSinkV2ExternalContext<T>
External context for DataStream sinks whose version is V2.
|
interface |
TableSinkExternalContext
External context for table sinks.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DataStreamSourceExternalContext<T>
External context for DataStream sources.
|
interface |
TableSourceExternalContext
External context for table sources.
|
Modifier and Type | Class and Description |
---|---|
interface |
TestContext
Marks the field in test class defining a
ExternalContextFactory for constructing ExternalContext before invocation of each test case. |
interface |
TestEnv
Marks the field in test class defining
TestEnvironment . |
interface |
TestExternalSystem
Marks the field in test class defining external system.
|
interface |
TestSemantics
Marks the field in test class defining supported semantic:
CheckpointingMode and CheckpointingMode (deprecated). |
Modifier and Type | Class and Description |
---|---|
class |
SinkTestSuiteBase<T extends Comparable<T>>
Base class for sink test suite.
|
class |
SourceTestSuiteBase<T>
Base class for all test suites.
|
Modifier and Type | Interface and Description |
---|---|
interface |
FailureEnricher
Failure Enricher enabling custom logic and attaching metadata in the form of labels to each type
of failure as tracked in the JobMaster.
|
static interface |
FailureEnricher.Context
An interface used by the
FailureEnricher . |
interface |
FailureEnricherFactory
Factory class for creating
FailureEnricher . |
Modifier and Type | Interface and Description |
---|---|
interface |
ByteBufferReadable
An interface mark that a filesystem supports to read bytes from a
ByteBuffer and its
given position. |
Modifier and Type | Interface and Description |
---|---|
interface |
DelegationTokenProvider
Delegation token provider API.
|
interface |
DelegationTokenReceiver
Delegation token receiver API.
|
Modifier and Type | Class and Description |
---|---|
class |
StateFutureUtils
A collection of utilities that expand the usage of
StateFuture . |
Modifier and Type | Interface and Description |
---|---|
interface |
ExecutionEnvironment
This is the context in which a program is executed.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Collector<OUT>
This class take response for collecting data to output stream.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JobInfo
JobInfo contains all the meta information of the job. |
static class |
JobInfo.ExecutionMode
Execution mode of this current job.
|
interface |
NonPartitionedContext<OUT>
This interface represents the context associated with all operations must be applied to all
partitions.
|
interface |
PartitionedContext
On the base of
RuntimeContext , PartitionedContext also contains all
partition-wise execution information, such as getting state, registering timer, etc. |
interface |
ProcessingTimeManager
This is responsibility for managing runtime information related to processing time of process
function.
|
interface |
RuntimeContext
A RuntimeContext contains information about the context in which process functions are executed.
|
interface |
StateManager
This is responsibility for managing runtime information related to state of process function.
|
interface |
TaskInfo
TaskInfo contains all the meta information of the task. |
interface |
TwoOutputNonPartitionedContext<OUT1,OUT2>
This interface represents the context associated with all operations must be applied to all
partitions with two outputs.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ApplyPartitionFunction<OUT>
A function to be applied to all partitions .
|
interface |
OneInputStreamProcessFunction<IN,OUT>
This contains all logical related to process records from single input.
|
interface |
ProcessFunction
Base class for all user defined process functions.
|
interface |
TwoInputBroadcastStreamProcessFunction<IN1,IN2,OUT>
This contains all logical related to process records from a broadcast stream and a non-broadcast
stream.
|
interface |
TwoInputNonBroadcastStreamProcessFunction<IN1,IN2,OUT>
This contains all logical related to process records from two non-broadcast input.
|
interface |
TwoOutputApplyPartitionFunction<OUT1,OUT2>
A function to be applied to all partitions with two outputs.
|
interface |
TwoOutputStreamProcessFunction<IN,OUT1,OUT2>
This contains all logical related to process and emit records to two output streams.
|
Modifier and Type | Interface and Description |
---|---|
interface |
BroadcastStream<T>
This interface represents a stream that each parallel task processes the same data.
|
interface |
DataStream
This is the topmost base interface of all streams of DataStream V2 API.
|
interface |
GlobalStream<T>
This interface represents a stream that force single parallelism.
|
static interface |
GlobalStream.ProcessConfigurableAndGlobalStream<T>
This interface represents a configurable
GlobalStream . |
static interface |
GlobalStream.TwoGlobalStreams<T1,T2>
This class represents a combination of two
GlobalStream . |
interface |
KeyedPartitionStream<K,T>
This interface represents a kind of partitioned data stream.
|
static interface |
KeyedPartitionStream.ProcessConfigurableAndKeyedPartitionStream<K,T>
This interface represents a configurable
KeyedPartitionStream . |
static interface |
KeyedPartitionStream.TwoKeyedPartitionStreams<K,T1,T2>
This class represents a combination of two
KeyedPartitionStream . |
interface |
NonKeyedPartitionStream<T>
This interface represents a kind of partitioned data stream.
|
static interface |
NonKeyedPartitionStream.ProcessConfigurableAndNonKeyedPartitionStream<T>
This interface represents a configurable
NonKeyedPartitionStream . |
static interface |
NonKeyedPartitionStream.TwoNonKeyedPartitionStreams<T1,T2>
This interface represents a combination of two
NonKeyedPartitionStream . |
interface |
ProcessConfigurable<T extends ProcessConfigurable<T>>
This represents the configuration handle of processing.
|
Modifier and Type | Class and Description |
---|---|
class |
AvroParquetReaders
A convenience builder to create
AvroParquetRecordFormat instances for the different kinds
of Avro record types. |
class |
AvroParquetWriters
Convenience builder to create
ParquetWriterFactory instances for the different Avro
types. |
Modifier and Type | Method and Description |
---|---|
default void |
MetricGroup.addSpan(SpanBuilder spanBuilder) |
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<String> |
PythonOptions.PYTHON_EXECUTION_MODE
Specify the python runtime execution mode.
|
static ConfigOption<Integer> |
PythonOptions.STATE_CACHE_SIZE
The maximum number of states cached in a Python UDF worker.
|
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Integer> |
TaskDeploymentDescriptorFactory.OFFLOAD_SHUFFLE_DESCRIPTORS_THRESHOLD
This is an expert option, that we do not want to expose in the documentation.
|
Modifier and Type | Interface and Description |
---|---|
interface |
InboundChannelHandlerFactory
Custom netty inbound handler factory in order to make custom changes on netty inbound data.
|
interface |
OutboundChannelHandlerFactory
Custom netty outbound handler factory in order to make custom changes on netty outbound data.
|
Modifier and Type | Class and Description |
---|---|
class |
StopWithSavepointStoppingException
Exception thrown when a savepoint has been created successfully when stopping with savepoint, but
the job has not finished.
|
Modifier and Type | Class and Description |
---|---|
class |
DelegationTokenContainer
Container for delegation tokens.
|
Modifier and Type | Interface and Description |
---|---|
static interface |
StateBackend.CustomInitializationMetrics |
Modifier and Type | Method and Description |
---|---|
default <K> AsyncKeyedStateBackend |
StateBackend.createAsyncKeyedStateBackend(StateBackend.KeyedStateBackendParameters<K> parameters)
Creates a new
AsyncKeyedStateBackend which supports to access keyed state
asynchronously. |
default boolean |
StateBackend.supportsAsyncKeyedStateBackend()
Tells if a state backend supports the
AsyncKeyedStateBackend . |
Modifier and Type | Interface and Description |
---|---|
interface |
ConfigurableForStOptionsFactory
An interface for options factory that pick up additional parameters from a configuration.
|
class |
ForStConfigurableOptions
This class contains the configuration options for the ForStStateBackend.
|
class |
ForStNativeMetricOptions
Enable which ForSt metrics to forward to Flink's metrics reporter.
|
class |
ForStOptions
Configuration options for the ForStStateBackend.
|
interface |
ForStOptionsFactory
A factory for
DBOptions and ColumnFamilyOptions to be passed to the
ForStStateBackend. |
class |
ForStStateBackend
A
StateBackend that stores its state in a ForSt instance. |
class |
ForStStateBackendFactory
A factory that creates an
ForStStateBackend from a configuration. |
Modifier and Type | Class and Description |
---|---|
class |
ByteBufferReadableFSDataInputStream
A
FSDataInputStream delegates requests to other one and supports reading data with ByteBuffer . |
class |
ByteBufferWritableFSDataOutputStream
A
FSDataOutputStream delegates requests to other one and supports writing data with
ByteBuffer . |
class |
ForStFlinkFileSystem
A
FileSystem delegates some requests to file system loaded by Flink FileSystem mechanism. |
Modifier and Type | Interface and Description |
---|---|
interface |
CommittableMessage<CommT>
The message send from
SinkWriter to Committer . |
class |
CommittableMessageTypeInfo<CommT>
The type information for the
CommittableMessage to make it consumable from a DataStream . |
class |
CommittableSummary<CommT>
This class tracks the information about committables belonging to one checkpoint coming from one
subtask.
|
class |
CommittableWithLineage<CommT>
Provides metadata.
|
class |
StandardSinkTopologies
This utility class provides building blocks for custom topologies.
|
interface |
SupportsPostCommitTopology<CommittableT>
Allows expert users to implement a custom topology after
Committer . |
interface |
SupportsPreCommitTopology<WriterResultT,CommittableT>
Allows expert users to implement a custom topology after
SinkWriter and before Committer . |
interface |
SupportsPreWriteTopology<InputT>
Allows expert users to implement a custom topology before
SinkWriter . |
interface |
WithPostCommitTopology<InputT,CommT>
Deprecated.
Please implement
Sink , SupportsCommitter and SupportsPostCommitTopology instead. |
interface |
WithPreCommitTopology<InputT,CommT>
Deprecated.
Please implement
Sink , SupportsCommitter and SupportsPreCommitTopology
instead. |
interface |
WithPreWriteTopology<InputT>
Deprecated.
Please implement
Sink and SupportsPreWriteTopology instead. |
Modifier and Type | Class and Description |
---|---|
static class |
DataStream.Collector<T>
This class acts as an accessor to elements collected via
DataStream.collectAsync(Collector) . |
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 |
---|---|
CloseableIterator<T> |
DataStream.collectAsync()
Sets up the collection of the elements in this
DataStream , and returns an iterator
over the collected elements that can be used to retrieve elements once the job execution has
started. |
void |
DataStream.collectAsync(DataStream.Collector<T> collector)
Sets up the collection of the elements in this
DataStream , which can be retrieved
later via the given DataStream.Collector . |
Modifier and Type | Method and Description |
---|---|
void |
CheckpointConfig.enableApproximateLocalRecovery(boolean enabled)
Enables the approximate local recovery mode.
|
void |
CheckpointConfig.enableUnalignedCheckpointsInterruptibleTimers(boolean enabled) |
<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.
|
boolean |
CheckpointConfig.isUnalignedCheckpointsInterruptibleTimersEnabled() |
Modifier and Type | Interface and Description |
---|---|
interface |
DataGenerator<T>
Stateful and re-scalable data generator.
|
class |
DataGeneratorSource<T>
Deprecated.
Use
org.apache.flink.connector.datagen.source.DataGeneratorSource instead. |
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 . |
class |
OperatorAttributes
OperatorAttributes element provides Job Manager with information that can be used to optimize job
performance.
|
class |
OperatorAttributesBuilder
The builder class for
OperatorAttributes . |
class |
StreamOperatorParameters<OUT>
Helper class to construct
AbstractStreamOperatorV2 . |
interface |
YieldingOperatorFactory<OUT>
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
Output.emitRecordAttributes(RecordAttributes recordAttributes)
Emits a
RecordAttributes from an operator. |
default OperatorAttributes |
StreamOperatorFactory.getOperatorAttributes()
Is called to get the OperatorAttributes of the operator.
|
default OperatorAttributes |
StreamOperator.getOperatorAttributes()
Called to get the OperatorAttributes of the operator.
|
default void |
Input.processRecordAttributes(RecordAttributes recordAttributes)
Processes a
RecordAttributes that arrived at this input. |
void |
AbstractStreamOperator.processRecordAttributes(RecordAttributes recordAttributes) |
default void |
TwoInputStreamOperator.processRecordAttributes1(RecordAttributes recordAttributes)
Processes a
RecordAttributes that arrived on the first input of this operator. |
void |
AbstractStreamOperator.processRecordAttributes1(RecordAttributes recordAttributes) |
default void |
TwoInputStreamOperator.processRecordAttributes2(RecordAttributes recordAttributes)
Processes a
RecordAttributes that arrived on the second input of this operator. |
void |
AbstractStreamOperator.processRecordAttributes2(RecordAttributes recordAttributes) |
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 | Class and Description |
---|---|
class |
RecordAttributes
A RecordAttributes describes the attributes of records from the current RecordAttributes until
the next one is received.
|
class |
RecordAttributesBuilder
The builder class for
RecordAttributes . |
Modifier and Type | Interface and Description |
---|---|
interface |
Compilable
Represents an artifact that can be compiled to a
CompiledPlan . |
interface |
CompiledPlan
Represents an immutable, fully optimized, and executable entity that has been compiled from a
Table & SQL API pipeline definition.
|
class |
PlanReference
Unresolved pointer to a persisted plan.
|
static class |
PlanReference.ContentPlanReference
Plan reference to a string containing the serialized persisted plan in JSON.
|
static class |
PlanReference.FilePlanReference
Plan reference to a file in the local filesystem.
|
static class |
PlanReference.ResourcePlanReference
Plan reference to a file in the provided
ClassLoader . |
Modifier and Type | Method and Description |
---|---|
CompiledPlan |
Compilable.compilePlan()
Compiles this object into a
CompiledPlan that can be executed as one job. |
CompiledPlan |
StatementSet.compilePlan()
Compiles this object into a
CompiledPlan that can be executed as one job. |
CompiledPlan |
TableEnvironment.compilePlanSql(String stmt)
Compiles a SQL DML statement into a
CompiledPlan . |
default TableResult |
TableEnvironment.executePlan(PlanReference planReference)
Shorthand for
tEnv.loadPlan(planReference).execute() . |
CompiledPlan |
TableEnvironment.loadPlan(PlanReference planReference)
Loads a plan from a
PlanReference into a CompiledPlan . |
Modifier and Type | Method and Description |
---|---|
CompiledPlan |
StatementSetImpl.compilePlan() |
CompiledPlan |
TableEnvironmentInternal.compilePlan(List<ModifyOperation> operations) |
TableResultInternal |
TableEnvironmentInternal.executePlan(InternalPlan plan) |
String |
TableEnvironmentInternal.explainPlan(InternalPlan compiledPlan,
ExplainDetail... extraDetails) |
Modifier and Type | Class and Description |
---|---|
class |
ClientWrapperClassLoader
This class loader extends
FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader , upon the addURL method, it
also exposes a removeURL method which used to remove unnecessary jar from current
classloader path. |
Modifier and Type | Method and Description |
---|---|
InternalPlan |
Planner.compilePlan(List<ModifyOperation> modifyOperations) |
String |
Planner.explainPlan(InternalPlan plan,
ExplainDetail... extraDetails) |
InternalPlan |
Planner.loadPlan(PlanReference planReference) |
List<Transformation<?>> |
Planner.translatePlan(InternalPlan plan) |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
InternalConfigOptions.TABLE_EXEC_NON_TEMPORAL_SORT_ENABLED |
Modifier and Type | Class and Description |
---|---|
class |
OutputFormatTableSink<T>
Deprecated.
This interface has been replaced by
DynamicTableSink . The new interface
consumes internal data structures. See FLIP-95 for more information. |
interface |
OverwritableTableSink
Deprecated.
This interface will not be supported in the new sink design around
DynamicTableSink . 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 . 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. See FLIP-95 for more information. |
interface |
LimitableTableSource<T>
Deprecated.
This interface will not be supported in the new source design around
DynamicTableSource . 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 . 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 . Use SupportsPartitionPushDown instead. See FLIP-95 for more
information. |
Modifier and Type | Class and Description |
---|---|
interface |
InjectClusterClient
Annotate a test method parameter with this annotation to inject the
ClusterClient or the
RestClusterClient instance. |
class |
MiniClusterExtension
Starts a Flink
MiniCluster and registers the respective ExecutionEnvironment and
StreamExecutionEnvironment in the correct thread local environment. |
Constructor and Description |
---|
MiniClusterExtension(Supplier<MiniClusterResourceConfiguration> miniClusterResourceConfigurationSupplier) |
Modifier and Type | Interface and Description |
---|---|
interface |
Span
Span represents something that happened in Flink at certain point of time, that will be reported
to a
TraceReporter . |
class |
SpanBuilder
Builder used to construct
Span . |
Modifier and Type | Interface and Description |
---|---|
interface |
TraceReporter
Trace reporters are used to export
Spans to an external backend. |
interface |
TraceReporterFactory
TraceReporter factory. |
Modifier and Type | Class and Description |
---|---|
class |
JacksonMapperFactory
Factory for Jackson mappers.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.