congrats Icon
New! Tabnine Pro 14-day free trial
Start a free trial
Tabnine Logo
ExecutionConfig.getAutoWatermarkInterval
Code IndexAdd Tabnine to your IDE (free)

How to use
getAutoWatermarkInterval
method
in
org.apache.flink.api.common.ExecutionConfig

Best Java code snippets using org.apache.flink.api.common.ExecutionConfig.getAutoWatermarkInterval (Showing top 20 results out of 315)

origin: apache/flink

@Override
public void open() throws Exception {
  super.open();
  currentWatermark = Long.MIN_VALUE;
  watermarkInterval = getExecutionConfig().getAutoWatermarkInterval();
  if (watermarkInterval > 0) {
    long now = getProcessingTimeService().getCurrentProcessingTime();
    getProcessingTimeService().registerTimer(now + watermarkInterval, this);
  }
}
origin: apache/flink

@Override
public void open() throws Exception {
  super.open();
  watermarkInterval = getExecutionConfig().getAutoWatermarkInterval();
  if (watermarkInterval > 0) {
    long now = getProcessingTimeService().getCurrentProcessingTime();
    getProcessingTimeService().registerTimer(now + watermarkInterval, this);
  }
  currentWatermark = Long.MIN_VALUE;
}
origin: apache/flink

watermarksPunctuated,
runtimeContext.getProcessingTimeService(),
runtimeContext.getExecutionConfig().getAutoWatermarkInterval(),
runtimeContext.getUserCodeClassLoader(),
runtimeContext.getTaskNameWithSubtasks(),
origin: apache/flink

watermarksPunctuated,
runtimeContext.getProcessingTimeService(),
runtimeContext.getExecutionConfig().getAutoWatermarkInterval(),
runtimeContext.getUserCodeClassLoader(),
runtimeContext.getTaskNameWithSubtasks(),
origin: apache/flink

watermarksPunctuated,
runtimeContext.getProcessingTimeService(),
runtimeContext.getExecutionConfig().getAutoWatermarkInterval(),
runtimeContext.getUserCodeClassLoader(),
runtimeContext.getTaskNameWithSubtasks(),
origin: apache/flink

public Kafka08Fetcher(
    SourceContext<T> sourceContext,
    Map<KafkaTopicPartition, Long> seedPartitionsWithInitialOffsets,
    SerializedValue<AssignerWithPeriodicWatermarks<T>> watermarksPeriodic,
    SerializedValue<AssignerWithPunctuatedWatermarks<T>> watermarksPunctuated,
    StreamingRuntimeContext runtimeContext,
    KeyedDeserializationSchema<T> deserializer,
    Properties kafkaProperties,
    long autoCommitInterval,
    MetricGroup consumerMetricGroup,
    boolean useMetrics) throws Exception {
  super(
      sourceContext,
      seedPartitionsWithInitialOffsets,
      watermarksPeriodic,
      watermarksPunctuated,
      runtimeContext.getProcessingTimeService(),
      runtimeContext.getExecutionConfig().getAutoWatermarkInterval(),
      runtimeContext.getUserCodeClassLoader(),
      consumerMetricGroup,
      useMetrics);
  this.deserializer = checkNotNull(deserializer);
  this.kafkaConfig = checkNotNull(kafkaProperties);
  this.runtimeContext = runtimeContext;
  this.invalidOffsetBehavior = getInvalidOffsetBehavior(kafkaProperties);
  this.autoCommitInterval = autoCommitInterval;
}
origin: apache/flink

@Override
public void open() throws Exception {
  super.open();
  checkState(this.reader == null, "The reader is already initialized.");
  checkState(this.serializer != null, "The serializer has not been set. " +
    "Probably the setOutputType() was not called. Please report it.");
  this.format.setRuntimeContext(getRuntimeContext());
  this.format.configure(new Configuration());
  this.checkpointLock = getContainingTask().getCheckpointLock();
  // set the reader context based on the time characteristic
  final TimeCharacteristic timeCharacteristic = getOperatorConfig().getTimeCharacteristic();
  final long watermarkInterval = getRuntimeContext().getExecutionConfig().getAutoWatermarkInterval();
  this.readerContext = StreamSourceContexts.getSourceContext(
    timeCharacteristic,
    getProcessingTimeService(),
    checkpointLock,
    getContainingTask().getStreamStatusMaintainer(),
    output,
    watermarkInterval,
    -1);
  // and initialize the split reading thread
  this.reader = new SplitReader<>(format, serializer, readerContext, checkpointLock, restoredReaderState);
  this.restoredReaderState = null;
  this.reader.start();
}
origin: apache/flink

operator.getContainingTask().getStreamStatusMaintainer(),
new CollectorOutput<String>(output),
operator.getExecutionConfig().getAutoWatermarkInterval(),
-1);
origin: apache/flink

final long watermarkInterval = getRuntimeContext().getExecutionConfig().getAutoWatermarkInterval();
origin: dataArtisans/flink-dataflow

private void setNextWatermarkTimer(StreamingRuntimeContext runtime) {
  if (this.isRunning) {
    long watermarkInterval =  runtime.getExecutionConfig().getAutoWatermarkInterval();
    long timeToNextWatermark = getTimeToNextWaternark(watermarkInterval);
    runtime.registerTimer(timeToNextWatermark, this);
  }
}
origin: org.apache.beam/beam-runners-flink_2.10

private void setNextWatermarkTimer(StreamingRuntimeContext runtime) {
 if (this.isRunning) {
  long watermarkInterval =  runtime.getExecutionConfig().getAutoWatermarkInterval();
  long timeToNextWatermark = getTimeToNextWatermark(watermarkInterval);
  runtime.getProcessingTimeService().registerTimer(timeToNextWatermark, this);
 }
}
origin: org.apache.flink/flink-streaming-java_2.11

@Override
public void open() throws Exception {
  super.open();
  currentWatermark = Long.MIN_VALUE;
  watermarkInterval = getExecutionConfig().getAutoWatermarkInterval();
  if (watermarkInterval > 0) {
    long now = getProcessingTimeService().getCurrentProcessingTime();
    getProcessingTimeService().registerTimer(now + watermarkInterval, this);
  }
}
origin: org.apache.flink/flink-streaming-java_2.10

@Override
public void open() throws Exception {
  super.open();
  watermarkInterval = getExecutionConfig().getAutoWatermarkInterval();
  if (watermarkInterval > 0) {
    long now = getProcessingTimeService().getCurrentProcessingTime();
    getProcessingTimeService().registerTimer(now + watermarkInterval, this);
  }
  currentWatermark = Long.MIN_VALUE;
}
origin: org.apache.flink/flink-streaming-java

@Override
public void open() throws Exception {
  super.open();
  currentWatermark = Long.MIN_VALUE;
  watermarkInterval = getExecutionConfig().getAutoWatermarkInterval();
  if (watermarkInterval > 0) {
    long now = getProcessingTimeService().getCurrentProcessingTime();
    getProcessingTimeService().registerTimer(now + watermarkInterval, this);
  }
}
origin: org.apache.flink/flink-streaming-java

@Override
public void open() throws Exception {
  super.open();
  watermarkInterval = getExecutionConfig().getAutoWatermarkInterval();
  if (watermarkInterval > 0) {
    long now = getProcessingTimeService().getCurrentProcessingTime();
    getProcessingTimeService().registerTimer(now + watermarkInterval, this);
  }
  currentWatermark = Long.MIN_VALUE;
}
origin: org.apache.flink/flink-streaming-java_2.11

@Override
public void open() throws Exception {
  super.open();
  watermarkInterval = getExecutionConfig().getAutoWatermarkInterval();
  if (watermarkInterval > 0) {
    long now = getProcessingTimeService().getCurrentProcessingTime();
    getProcessingTimeService().registerTimer(now + watermarkInterval, this);
  }
  currentWatermark = Long.MIN_VALUE;
}
origin: org.apache.flink/flink-streaming-java_2.10

@Override
public void open() throws Exception {
  super.open();
  currentWatermark = Long.MIN_VALUE;
  watermarkInterval = getExecutionConfig().getAutoWatermarkInterval();
  if (watermarkInterval > 0) {
    long now = getProcessingTimeService().getCurrentProcessingTime();
    getProcessingTimeService().registerTimer(now + watermarkInterval, this);
  }
}
origin: com.alibaba.blink/flink-table

@Override
public void open() throws Exception {
  super.open();
  // watermark and timestamp should start from 0
  currentWatermark = 0;
  currentMaxTimestamp = 0;
  watermarkInterval = getExecutionConfig().getAutoWatermarkInterval();
  if (watermarkInterval > 0) {
    long now = getProcessingTimeService().getCurrentProcessingTime();
    getProcessingTimeService().registerTimer(now + watermarkInterval, this);
  }
}
origin: org.apache.beam/beam-runners-flink

@SuppressWarnings("FutureReturnValueIgnored")
private void setNextWatermarkTimer(StreamingRuntimeContext runtime) {
 if (this.isRunning) {
  long watermarkInterval = runtime.getExecutionConfig().getAutoWatermarkInterval();
  synchronized (context.getCheckpointLock()) {
   long timeToNextWatermark =
     runtime.getProcessingTimeService().getCurrentProcessingTime() + watermarkInterval;
   runtime.getProcessingTimeService().registerTimer(timeToNextWatermark, this);
  }
 }
}
origin: org.apache.beam/beam-runners-flink_2.11

@SuppressWarnings("FutureReturnValueIgnored")
private void setNextWatermarkTimer(StreamingRuntimeContext runtime) {
 if (this.isRunning) {
  long watermarkInterval = runtime.getExecutionConfig().getAutoWatermarkInterval();
  synchronized (context.getCheckpointLock()) {
   long currentProcessingTime = runtime.getProcessingTimeService().getCurrentProcessingTime();
   if (currentProcessingTime < Long.MAX_VALUE) {
    long nextTriggerTime = currentProcessingTime + watermarkInterval;
    if (nextTriggerTime < currentProcessingTime) {
     // overflow, just trigger once for the max timestamp
     nextTriggerTime = Long.MAX_VALUE;
    }
    runtime.getProcessingTimeService().registerTimer(nextTriggerTime, this);
   }
  }
 }
}
org.apache.flink.api.commonExecutionConfiggetAutoWatermarkInterval

Javadoc

Returns the interval of the automatic watermark emission.

Popular methods of ExecutionConfig

  • <init>
  • isObjectReuseEnabled
    Returns whether object reuse has been enabled or disabled. @see #enableObjectReuse()
  • disableSysoutLogging
    Disables the printing of progress update messages to System.out
  • setGlobalJobParameters
    Register a custom, serializable user configuration object.
  • enableObjectReuse
    Enables reusing objects that Flink internally uses for deserialization and passing data to user-code
  • setAutoWatermarkInterval
    Sets the interval of the automatic watermark emission. Watermarks are used throughout the streaming
  • disableObjectReuse
    Disables reusing objects that Flink internally uses for deserialization and passing data to user-cod
  • getRestartStrategy
    Returns the restart strategy which has been set for the current job.
  • isSysoutLoggingEnabled
    Gets whether progress update messages should be printed to System.out
  • registerKryoType
    Registers the given type with the serialization stack. If the type is eventually serialized as a POJ
  • registerTypeWithKryoSerializer
    Registers the given Serializer via its class as a serializer for the given type at the KryoSerialize
  • setRestartStrategy
    Sets the restart strategy to be used for recovery. ExecutionConfig config = env.getConfig();
  • registerTypeWithKryoSerializer,
  • setRestartStrategy,
  • getParallelism,
  • addDefaultKryoSerializer,
  • getGlobalJobParameters,
  • getNumberOfExecutionRetries,
  • getRegisteredKryoTypes,
  • setParallelism,
  • getDefaultKryoSerializerClasses

Popular in Java

  • Parsing JSON documents to java classes using gson
  • runOnUiThread (Activity)
  • getOriginalFilename (MultipartFile)
    Return the original filename in the client's filesystem.This may contain path information depending
  • putExtra (Intent)
  • Graphics2D (java.awt)
    This Graphics2D class extends the Graphics class to provide more sophisticated control overgraphics
  • Window (java.awt)
    A Window object is a top-level window with no borders and no menubar. The default layout for a windo
  • Charset (java.nio.charset)
    A charset is a named mapping between Unicode characters and byte sequences. Every Charset can decode
  • SecureRandom (java.security)
    This class generates cryptographically secure pseudo-random numbers. It is best to invoke SecureRand
  • Date (java.util)
    A specific moment in time, with millisecond precision. Values typically come from System#currentTime
  • Logger (org.apache.log4j)
    This is the central class in the log4j package. Most logging operations, except configuration, are d
  • Top 17 Free Sublime Text Plugins
Tabnine Logo
  • Products

    Search for Java codeSearch for JavaScript code
  • IDE Plugins

    IntelliJ IDEAWebStormVisual StudioAndroid StudioEclipseVisual Studio CodePyCharmSublime TextPhpStormVimAtomGoLandRubyMineEmacsJupyter NotebookJupyter LabRiderDataGripAppCode
  • Company

    About UsContact UsCareers
  • Resources

    FAQBlogTabnine AcademyStudentsTerms of usePrivacy policyJava Code IndexJavascript Code Index
Get Tabnine for your IDE now