程序包 | 说明 |
---|---|
org.apache.flink.streaming.api | |
org.apache.flink.streaming.api.environment | |
org.apache.flink.streaming.api.graph | |
org.apache.flink.streaming.api.operators |
限定符和类型 | 方法和说明 |
---|---|
static TimeCharacteristic |
TimeCharacteristic.valueOf(String name)
已过时。
返回带有指定名称的该类型的枚举常量。
|
static TimeCharacteristic[] |
TimeCharacteristic.values()
已过时。
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
|
限定符和类型 | 字段和说明 |
---|---|
static org.apache.flink.configuration.ConfigOption<TimeCharacteristic> |
StreamPipelineOptions.TIME_CHARACTERISTIC |
限定符和类型 | 方法和说明 |
---|---|
TimeCharacteristic |
StreamExecutionEnvironment.getStreamTimeCharacteristic()
已过时。
See
StreamExecutionEnvironment.setStreamTimeCharacteristic(TimeCharacteristic) for deprecation
notice. |
限定符和类型 | 方法和说明 |
---|---|
void |
StreamExecutionEnvironment.setStreamTimeCharacteristic(TimeCharacteristic characteristic)
已过时。
In Flink 1.12 the default stream time characteristic has been changed to
EventTime , thus you don't need to call this method for enabling
event-time support anymore. Explicitly using processing-time windows and timers works in
event-time mode. If you need to disable watermarks, please use ExecutionConfig.setAutoWatermarkInterval(long) . If you are using IngestionTime , please manually set an appropriate WatermarkStrategy . If you are using generic "time window" operations (for example KeyedStream.timeWindow(org.apache.flink.streaming.api.windowing.time.Time)
that change behaviour based on the time characteristic, please use equivalent operations
that explicitly specify processing time or event time. |
限定符和类型 | 字段和说明 |
---|---|
static TimeCharacteristic |
StreamGraphGenerator.DEFAULT_TIME_CHARACTERISTIC |
限定符和类型 | 方法和说明 |
---|---|
TimeCharacteristic |
StreamConfig.getTimeCharacteristic() |
TimeCharacteristic |
StreamGraph.getTimeCharacteristic() |
限定符和类型 | 方法和说明 |
---|---|
StreamGraphGenerator |
StreamGraphGenerator.setTimeCharacteristic(TimeCharacteristic timeCharacteristic) |
void |
StreamConfig.setTimeCharacteristic(TimeCharacteristic characteristic) |
void |
StreamGraph.setTimeCharacteristic(TimeCharacteristic timeCharacteristic) |
限定符和类型 | 方法和说明 |
---|---|
static <OUT> SourceFunction.SourceContext<OUT> |
StreamSourceContexts.getSourceContext(TimeCharacteristic timeCharacteristic,
ProcessingTimeService processingTimeService,
Object checkpointLock,
StreamStatusMaintainer streamStatusMaintainer,
Output<StreamRecord<OUT>> output,
long watermarkInterval,
long idleTimeout)
Depending on the
TimeCharacteristic , this method will return the adequate SourceFunction.SourceContext . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.