閱讀994 返回首頁    go 阿裏雲 go 技術社區[雲棲]


Flink – Trigger,Evictor

org.apache.flink.streaming.api.windowing.triggers;

 

Trigger

複製代碼
public abstract class Trigger<T, W extends Window> implements Serializable {

    /**
     * Called for every element that gets added to a pane. The result of this will determine
     * whether the pane is evaluated to emit results.
     *
     * @param element The element that arrived.
     * @param timestamp The timestamp of the element that arrived.
     * @param window The window to which the element is being added.
     * @param ctx A context object that can be used to register timer callbacks.
     */
    public abstract TriggerResult onElement(T element, long timestamp, W window, TriggerContext ctx) throws Exception;

    /**
     * Called when a processing-time timer that was set using the trigger context fires.
     *
     * @param time The timestamp at which the timer fired.
     * @param window The window for which the timer fired.
     * @param ctx A context object that can be used to register timer callbacks.
     */
    public abstract TriggerResult onProcessingTime(long time, W window, TriggerContext ctx) throws Exception;

    /**
     * Called when an event-time timer that was set using the trigger context fires.
     *
     * @param time The timestamp at which the timer fired.
     * @param window The window for which the timer fired.
     * @param ctx A context object that can be used to register timer callbacks.
     */
    public abstract TriggerResult onEventTime(long time, W window, TriggerContext ctx) throws Exception;

    /**
     * Called when several windows have been merged into one window by the
     * {@link org.apache.flink.streaming.api.windowing.assigners.WindowAssigner}.
     *
     * @param window The new window that results from the merge.
     * @param ctx A context object that can be used to register timer callbacks and access state.
     */
    public TriggerResult onMerge(W window, OnMergeContext ctx) throws Exception {
        throw new RuntimeException("This trigger does not support merging.");
    }
複製代碼

Trigger決定pane何時被evaluated,實現一係列接口,來判斷各種情況下是否需要trigger

看看具體的trigger的實現,

ProcessingTimeTrigger

複製代碼
/**
 * A {@link Trigger} that fires once the current system time passes the end of the window
 * to which a pane belongs.
 */
public class ProcessingTimeTrigger implements Trigger<Object, TimeWindow> {
    private static final long serialVersionUID = 1L;
    
    private ProcessingTimeTrigger() {}
    
    @Override
    public TriggerResult onElement(Object element, long timestamp, TimeWindow window, TriggerContext ctx) {
        ctx.registerProcessingTimeTimer(window.maxTimestamp()); //對於processingTime,element的trigger時間是current+window,所以這裏需要注冊定時器去觸發
        return TriggerResult.CONTINUE;
    }
    
    @Override
    public TriggerResult onEventTime(long time, TimeWindow window, TriggerContext ctx) throws Exception {
        return TriggerResult.CONTINUE;
    }
    
    @Override
    public TriggerResult onProcessingTime(long time, TimeWindow window, TriggerContext ctx) {//觸發後調用
        return TriggerResult.FIRE_AND_PURGE;
    }
    
    @Override
    public String toString() {
        return "ProcessingTimeTrigger()";
    }
    
    /**
    * Creates a new trigger that fires once system time passes the end of the window.
    */
    public static ProcessingTimeTrigger create() {
        return new ProcessingTimeTrigger();
    }
}
複製代碼

可以看到隻有在onProcessingTime的時候,是FIRE_AND_PURGE,其他時候都是continue

再看個CountTrigger,

複製代碼
public class CountTrigger<W extends Window> extends Trigger<Object, W> {

    private final long maxCount;

    private final ReducingStateDescriptor<Long> stateDesc =
            new ReducingStateDescriptor<>("count", new Sum(), LongSerializer.INSTANCE);

    private CountTrigger(long maxCount) {
        this.maxCount = maxCount;
    }

    @Override
    public TriggerResult onElement(Object element, long timestamp, W window, TriggerContext ctx) throws Exception {
        ReducingState<Long> count = ctx.getPartitionedState(stateDesc); //從backend取出conunt state
        count.add(1L); //加1
        if (count.get() >= maxCount) {
            count.clear();
            return TriggerResult.FIRE;
        }
        return TriggerResult.CONTINUE;
    }

    @Override
    public TriggerResult onEventTime(long time, W window, TriggerContext ctx) {
        return TriggerResult.CONTINUE;
    }

    @Override
    public TriggerResult onProcessingTime(long time, W window, TriggerContext ctx) throws Exception {
        return TriggerResult.CONTINUE;
    }

    @Override
    public TriggerResult onMerge(W window, OnMergeContext ctx) throws Exception {
        ctx.mergePartitionedState(stateDesc); //先調用merge,底層backend裏麵的window進行merge
        ReducingState<Long> count = ctx.getPartitionedState(stateDesc); //merge後再取出state,count,進行判斷
        if (count.get() >= maxCount) {
            return TriggerResult.FIRE;
        }
        return TriggerResult.CONTINUE;
    }
複製代碼

很簡單,既然是算count,那麼和time相關的自然都是continue

對於count,是在onElement中觸發,每次來element都會走到這個邏輯

當累積的count > 設定的count時,就會返回Fire,注意,這裏這是fire,並不會purge

並將計數清0

 

TriggerResult

TriggerResult是個枚舉,

enum TriggerResult {
    CONTINUE(false, false), FIRE_AND_PURGE(true, true), FIRE(true, false), PURGE(false, true);
    
    private final boolean fire;
    private final boolean purge;
}

兩個選項,fire,purge,2×2,所以4種可能性

兩個Result可以merge,

複製代碼
/**
 * Merges two {@code TriggerResults}. This specifies what should happen if we have
 * two results from a Trigger, for example as a result from
 * {@link Trigger#onElement(Object, long, Window, Trigger.TriggerContext)} and
 * {@link Trigger#onEventTime(long, Window, Trigger.TriggerContext)}.
 *
 * <p>
 * For example, if one result says {@code CONTINUE} while the other says {@code FIRE}
 * then {@code FIRE} is the combined result;
 */
public static TriggerResult merge(TriggerResult a, TriggerResult b) {
    if (a.purge || b.purge) {
        if (a.fire || b.fire) {
            return FIRE_AND_PURGE;
        } else {
            return PURGE;
        }
    } else if (a.fire || b.fire) {
        return FIRE;
    } else {
        return CONTINUE;
    }
}
複製代碼

 

TriggerContext

為Trigger做些環境的工作,比如管理timer,和處理state

這些接口在,Trigger中的接口邏輯裏麵都會用到,所以在Trigger的所有接口上,都需要傳入context

複製代碼
/**
     * A context object that is given to {@link Trigger} methods to allow them to register timer
     * callbacks and deal with state.
     */
    public interface TriggerContext {

        long getCurrentProcessingTime();
        long getCurrentWatermark();
    
        /**
         * Register a system time callback. When the current system time passes the specified
         * time {@link Trigger#onProcessingTime(long, Window, TriggerContext)} is called with the time specified here.
         *
         * @param time The time at which to invoke {@link Trigger#onProcessingTime(long, Window, TriggerContext)}
         */
        void registerProcessingTimeTimer(long time);
        void registerEventTimeTimer(long time);
    
        void deleteProcessingTimeTimer(long time);
        void deleteEventTimeTimer(long time);
    

        <S extends State> S getPartitionedState(StateDescriptor<S, ?> stateDescriptor);
    }
複製代碼

 

OnMergeContext 僅僅是多了一個接口,

public interface OnMergeContext extends TriggerContext {
    <S extends MergingState<?, ?>> void mergePartitionedState(StateDescriptor<S, ?> stateDescriptor);
}

 

WindowOperator.Context作為TriggerContext的一個實現,

複製代碼
/**
 * {@code Context} is a utility for handling {@code Trigger} invocations. It can be reused
 * by setting the {@code key} and {@code window} fields. No internal state must be kept in
 * the {@code Context}
 */
public class Context implements Trigger.OnMergeContext {
    protected K key; //Context對應的window上下文
    protected W window;

    protected Collection<W> mergedWindows; //onMerge中被賦值

    @SuppressWarnings("unchecked")
    public <S extends State> S getPartitionedState(StateDescriptor<S, ?> stateDescriptor) {
        try {
            return WindowOperator.this.getPartitionedState(window, windowSerializer, stateDescriptor); //從backend裏麵讀出改window的狀態,即window buffer
        } catch (Exception e) {
            throw new RuntimeException("Could not retrieve state", e);
        }
    }

    @Override
    public <S extends MergingState<?, ?>> void mergePartitionedState(StateDescriptor<S, ?> stateDescriptor) {
        if (mergedWindows != null && mergedWindows.size() > 0) {
            try {
                WindowOperator.this.getStateBackend().mergePartitionedStates(window, //在backend層麵把mergedWindows merge到window中
                        mergedWindows,
                        windowSerializer,
                        stateDescriptor);
            } catch (Exception e) {
                throw new RuntimeException("Error while merging state.", e);
            }
        }
    }

    @Override
    public void registerProcessingTimeTimer(long time) {
        Timer<K, W> timer = new Timer<>(time, key, window);
        // make sure we only put one timer per key into the queue
        if (processingTimeTimers.add(timer)) {
            processingTimeTimersQueue.add(timer);
            //If this is the first timer added for this timestamp register a TriggerTask
            if (processingTimeTimerTimestamps.add(time, 1) == 0) { //如果這個window是第一次注冊的話
                ScheduledFuture<?> scheduledFuture = WindowOperator.this.registerTimer(time, WindowOperator.this); //對於processTime必須注冊定時器主動觸發
                processingTimeTimerFutures.put(time, scheduledFuture);
            }
        }
    }

    @Override
    public void registerEventTimeTimer(long time) {
        Timer<K, W> timer = new Timer<>(time, key, window);
        if (watermarkTimers.add(timer)) {
            watermarkTimersQueue.add(timer);
        }
    }

    //封裝一遍trigger的接口,並把self作為context傳入trigger的接口中
    public TriggerResult onElement(StreamRecord<IN> element) throws Exception {
        return trigger.onElement(element.getValue(), element.getTimestamp(), window, this);
    }

    public TriggerResult onProcessingTime(long time) throws Exception {
        return trigger.onProcessingTime(time, window, this);
    }

    public TriggerResult onEventTime(long time) throws Exception {
        return trigger.onEventTime(time, window, this);
    }

    public TriggerResult onMerge(Collection<W> mergedWindows) throws Exception {
        this.mergedWindows = mergedWindows;
        return trigger.onMerge(window, this);
    }

}

 
複製代碼

 

Evictor

複製代碼
/**
 * An {@code Evictor} can remove elements from a pane before it is being processed and after
 * window evaluation was triggered by a
 * {@link org.apache.flink.streaming.api.windowing.triggers.Trigger}.
 *
 * <p>
 * A pane is the bucket of elements that have the same key (assigned by the
 * {@link org.apache.flink.api.java.functions.KeySelector}) and same {@link Window}. An element can
 * be in multiple panes of it was assigned to multiple windows by the
 * {@link org.apache.flink.streaming.api.windowing.assigners.WindowAssigner}. These panes all
 * have their own instance of the {@code Evictor}.
 *
 * @param <T> The type of elements that this {@code Evictor} can evict.
 * @param <W> The type of {@link Window Windows} on which this {@code Evictor} can operate.
 */
public interface Evictor<T, W extends Window> extends Serializable {

    /**
     * Computes how many elements should be removed from the pane. The result specifies how
     * many elements should be removed from the beginning.
     *
     * @param elements The elements currently in the pane.
     * @param size The current number of elements in the pane.
     * @param window The {@link Window}
     */
    int evict(Iterable<StreamRecord<T>> elements, int size, W window);
}
複製代碼

Evictor的目的就是在Trigger fire後,但在element真正被處理前,從pane中remove掉一些數據

比如你雖然是每小時觸發一次,但是隻是想處理最後10分鍾的數據,而不是所有數據。。。

 

CountEvictor

複製代碼
/**
 * An {@link Evictor} that keeps only a certain amount of elements.
 *
 * @param <W> The type of {@link Window Windows} on which this {@code Evictor} can operate.
 */
public class CountEvictor<W extends Window> implements Evictor<Object, W> {
    private static final long serialVersionUID = 1L;
    
    private final long maxCount;
    
    private CountEvictor(long count) {
        this.maxCount = count;
    }
    
    @Override
    public int evict(Iterable<StreamRecord<Object>> elements, int size, W window) {
        if (size > maxCount) {
            return (int) (size - maxCount);
        } else {
            return 0;
        }
    }
    
    /**
    * Creates a {@code CountEvictor} that keeps the given number of elements.
    *
    * @param maxCount The number of elements to keep in the pane.
    */
    public static <W extends Window> CountEvictor<W> of(long maxCount) {
        return new CountEvictor<>(maxCount);
    }
}
複製代碼

初始化count,表示想保留多少elements(from end)

evict返回需要刪除的elements數目(from begining)

如果element數大於保留數,我們需要刪除size – maxCount(from begining)

反之,就全保留

 

TimeEvictor

複製代碼
/**
 * An {@link Evictor} that keeps elements for a certain amount of time. Elements older
 * than {@code current_time - keep_time} are evicted.
 *
 * @param <W> The type of {@link Window Windows} on which this {@code Evictor} can operate.
 */
public class TimeEvictor<W extends Window> implements Evictor<Object, W> {
    private static final long serialVersionUID = 1L;
    
    private final long windowSize;
    
    public TimeEvictor(long windowSize) {
        this.windowSize = windowSize;
    }
    
    @Override
    public int evict(Iterable<StreamRecord<Object>> elements, int size, W window) {
        int toEvict = 0;
        long currentTime = Iterables.getLast(elements).getTimestamp();
        long evictCutoff = currentTime - windowSize;
        for (StreamRecord<Object> record: elements) {
            if (record.getTimestamp() > evictCutoff) {
                break;
            }
            toEvict++;
        }
        return toEvict;
    }
}
複製代碼

TimeEvictor設置需要保留的時間,

用最後一條的時間作為current,current-windowSize,作為界限,小於這個時間的要evict掉

這裏的前提是,數據是時間有序的

最後更新:2017-04-07 21:23:50

  上一篇:go Flink -- Failover
  下一篇:go Flink - state管理