java.lang.Object
org.apache.beam.runners.flink.translation.utils.Workarounds

public class Workarounds extends Object
Workarounds for dealing with limitations of Flink or its libraries.
  • Constructor Details

    • Workarounds

      public Workarounds()
  • Method Details

    • deleteStaticCaches

      public static void deleteStaticCaches()
    • retrieveInternalProcessingTimerQueue

      public static org.apache.flink.runtime.state.InternalPriorityQueue<org.apache.flink.streaming.api.operators.InternalTimer<Object,org.apache.beam.runners.core.TimerInternals.TimerData>> retrieveInternalProcessingTimerQueue(org.apache.flink.streaming.api.operators.InternalTimerService<org.apache.beam.runners.core.TimerInternals.TimerData> timerService)