Package | Description |
---|---|
org.apache.flink.state.api.runtime | |
org.apache.flink.streaming.api.functions.sink.filesystem | |
org.apache.flink.streaming.connectors.fs.bucketing | |
org.apache.flink.streaming.runtime.operators |
This package contains the operators that perform the stream transformations.
|
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
org.apache.flink.table.runtime.operators.wmassigners |
Modifier and Type | Method and Description |
---|---|
ScheduledFuture<?> |
NeverFireProcessingTimeService.registerTimer(long timestamp,
ProcessingTimeCallback target) |
ScheduledFuture<?> |
NeverFireProcessingTimeService.scheduleAtFixedRate(ProcessingTimeCallback callback,
long initialDelay,
long period) |
ScheduledFuture<?> |
NeverFireProcessingTimeService.scheduleWithFixedDelay(ProcessingTimeCallback callback,
long initialDelay,
long period) |
Modifier and Type | Class and Description |
---|---|
class |
StreamingFileSinkHelper<IN>
Helper for
StreamingFileSink . |
Modifier and Type | Class and Description |
---|---|
class |
BucketingSink<T>
Deprecated.
Please use the
StreamingFileSink
instead. |
Modifier and Type | Class and Description |
---|---|
class |
TimestampsAndWatermarksOperator<T>
A stream operator that may do one or both of the following: extract timestamps from events and
generate watermarks.
|
Modifier and Type | Method and Description |
---|---|
ScheduledFuture<?> |
ProcessingTimeService.registerTimer(long timestamp,
ProcessingTimeCallback target)
Registers a task to be executed when (processing) time is
timestamp . |
ScheduledFuture<?> |
TestProcessingTimeService.registerTimer(long timestamp,
ProcessingTimeCallback target) |
ScheduledFuture<?> |
SystemProcessingTimeService.registerTimer(long timestamp,
ProcessingTimeCallback callback)
Registers a task to be executed no sooner than time
timestamp , but without strong
guarantees of order. |
ScheduledFuture<?> |
ProcessingTimeService.scheduleAtFixedRate(ProcessingTimeCallback callback,
long initialDelay,
long period)
Registers a task to be executed repeatedly at a fixed rate.
|
ScheduledFuture<?> |
TestProcessingTimeService.scheduleAtFixedRate(ProcessingTimeCallback callback,
long initialDelay,
long period) |
ScheduledFuture<?> |
SystemProcessingTimeService.scheduleAtFixedRate(ProcessingTimeCallback callback,
long initialDelay,
long period) |
ScheduledFuture<?> |
ProcessingTimeService.scheduleWithFixedDelay(ProcessingTimeCallback callback,
long initialDelay,
long period)
Registers a task to be executed repeatedly with a fixed delay.
|
ScheduledFuture<?> |
TestProcessingTimeService.scheduleWithFixedDelay(ProcessingTimeCallback callback,
long initialDelay,
long period) |
ScheduledFuture<?> |
SystemProcessingTimeService.scheduleWithFixedDelay(ProcessingTimeCallback callback,
long initialDelay,
long period) |
Modifier and Type | Class and Description |
---|---|
class |
ProcTimeMiniBatchAssignerOperator
A stream operator that emits mini-batch marker in a given period.
|
class |
WatermarkAssignerOperator
A stream operator that extracts timestamps from stream elements and generates periodic
watermarks.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.