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, lastRecordAttributes1, lastRecordAttributes2, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
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. state initialization.
|
void |
processWatermark(Watermark mark) |
boolean |
useSplittableTimers()
Can be overridden to disable splittable timers for this particular operator even if config
option is enabled.
|
close, finish, getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getOperatorAttributes
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 boolean useSplittableTimers()
AbstractStreamOperator
useSplittableTimers
in class AbstractStreamOperator<OUT>
true
if splittable timers should be used (subject to StreamConfig.isUnalignedCheckpointsEnabled()
and StreamConfig.isUnalignedCheckpointsSplittableTimersEnabled()
. false
if
splittable timers should never be used.public long computeMemorySize()
public void processWatermark(Watermark mark) throws Exception
processWatermark
in class AbstractStreamOperator<OUT>
Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.