Package | Description |
---|---|
org.apache.flink.streaming.api.operators | |
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.
|
Modifier and Type | Class and Description |
---|---|
class |
HeapInternalTimerService<K,N>
InternalTimerService that stores timers on the Java heap. |
Modifier and Type | Class and Description |
---|---|
class |
BucketingSink<T>
Sink that emits its input elements to
FileSystem files within
buckets. |
Modifier and Type | Class and Description |
---|---|
class |
ExtractTimestampsOperator<T>
Deprecated.
|
class |
TimestampsAndPeriodicWatermarksOperator<T>
A stream operator that extracts timestamps from stream elements and
generates periodic watermarks.
|
Modifier and Type | Method and Description |
---|---|
ScheduledFuture<?> |
SystemProcessingTimeService.registerTimer(long timestamp,
ProcessingTimeCallback target)
Registers a task to be executed no sooner than time
timestamp , but without strong
guarantees of order. |
abstract 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.scheduleAtFixedRate(ProcessingTimeCallback callback,
long initialDelay,
long period) |
abstract 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) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.