public abstract class TableStreamOperator<OUT> extends AbstractStreamOperator<OUT>
Modifier and Type | Class and Description |
---|---|
protected class |
TableStreamOperator.ContextImpl
Information available in an invocation of processElement.
|
Modifier and Type | Field and Description |
---|---|
protected TableStreamOperator.ContextImpl |
ctx |
protected long |
currentWatermark
We listen to this ourselves because we don't have an
InternalTimerService . |
chainingStrategy, config, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
TableStreamOperator() |
Modifier and Type | Method and Description |
---|---|
long |
computeMemorySize()
Compute memory size from memory faction.
|
void |
open()
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic, e.g.
|
void |
processWatermark(Watermark mark) |
close, finish, getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, setup, snapshotState, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
hasKeyContext
protected long currentWatermark
InternalTimerService
.protected transient TableStreamOperator.ContextImpl ctx
public void open() throws Exception
AbstractStreamOperator
The default implementation does nothing.
open
in interface StreamOperator<OUT>
open
in class AbstractStreamOperator<OUT>
Exception
- An exception in this method causes the operator to fail.public void processWatermark(Watermark mark) throws Exception
processWatermark
in class AbstractStreamOperator<OUT>
Exception
public long computeMemorySize()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.