Modifier and Type | Method and Description |
---|---|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.flatSelect(OutputTag<L> timedOutPartialMatchesTag,
PatternFlatTimeoutFunction<T,L> patternFlatTimeoutFunction,
PatternFlatSelectFunction<T,R> patternFlatSelectFunction)
Applies a flat select function to the detected pattern sequence.
|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.flatSelect(OutputTag<L> timedOutPartialMatchesTag,
PatternFlatTimeoutFunction<T,L> patternFlatTimeoutFunction,
TypeInformation<R> outTypeInfo,
PatternFlatSelectFunction<T,R> patternFlatSelectFunction)
Applies a flat select function to the detected pattern sequence.
|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.select(OutputTag<L> timedOutPartialMatchesTag,
PatternTimeoutFunction<T,L> patternTimeoutFunction,
PatternSelectFunction<T,R> patternSelectFunction)
Applies a select function to the detected pattern sequence.
|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.select(OutputTag<L> timedOutPartialMatchesTag,
PatternTimeoutFunction<T,L> patternTimeoutFunction,
TypeInformation<R> outTypeInfo,
PatternSelectFunction<T,R> patternSelectFunction)
Applies a select function to the detected pattern sequence.
|
PatternStream<T> |
PatternStream.sideOutputLateData(OutputTag<T> lateDataOutputTag)
Send late arriving data to the side output identified by the given
OutputTag . |
Modifier and Type | Method and Description |
---|---|
<X> void |
PatternProcessFunction.Context.output(OutputTag<X> outputTag,
X value)
Emits a record to the side output identified by the
OutputTag . |
Constructor and Description |
---|
PatternTimeoutFlatSelectAdapter(PatternFlatSelectFunction<IN,OUT> flatSelectFunction,
PatternFlatTimeoutFunction<IN,T> flatTimeoutFunction,
OutputTag<T> timedOutPartialMatchesTag) |
PatternTimeoutSelectAdapter(PatternSelectFunction<IN,OUT> selectFunction,
PatternTimeoutFunction<IN,T> timeoutFunction,
OutputTag<T> timedOutPartialMatchesTag) |
Constructor and Description |
---|
CepOperator(TypeSerializer<IN> inputSerializer,
boolean isProcessingTime,
NFACompiler.NFAFactory<IN> nfaFactory,
EventComparator<IN> comparator,
AfterMatchSkipStrategy afterMatchSkipStrategy,
PatternProcessFunction<IN,OUT> function,
OutputTag<IN> lateDataOutputTag) |
Modifier and Type | Field and Description |
---|---|
protected OutputTag<OUT_SIDE> |
TwoOutputProcessOperator.outputTag |
Constructor and Description |
---|
KeyedTwoOutputProcessOperator(TwoOutputStreamProcessFunction<IN,OUT_MAIN,OUT_SIDE> userFunction,
OutputTag<OUT_SIDE> outputTag) |
KeyedTwoOutputProcessOperator(TwoOutputStreamProcessFunction<IN,OUT_MAIN,OUT_SIDE> userFunction,
OutputTag<OUT_SIDE> outputTag,
KeySelector<OUT_MAIN,KEY> mainOutKeySelector,
KeySelector<OUT_SIDE,KEY> sideOutKeySelector) |
TwoOutputProcessOperator(TwoOutputStreamProcessFunction<IN,OUT_MAIN,OUT_SIDE> userFunction,
OutputTag<OUT_SIDE> outputTag) |
Modifier and Type | Field and Description |
---|---|
protected Map<OutputTag<?>,TypeInformation<?>> |
AbstractDataStream.requestedSideOutputs
We keep track of the side outputs that were already requested and their types.
|
Modifier and Type | Method and Description |
---|---|
<X> Transformation<X> |
AbstractDataStream.getSideOutputTransform(OutputTag<X> outputTag) |
Modifier and Type | Method and Description |
---|---|
<X> SideOutputDataStream<X> |
SingleOutputStreamOperator.getSideOutput(OutputTag<X> sideOutputTag)
Gets the
DataStream that contains the elements that are emitted from an operation
into the side output with the given OutputTag . |
WindowedStream<T,K,W> |
WindowedStream.sideOutputLateData(OutputTag<T> outputTag)
Send late arriving data to the side output identified by the given
OutputTag . |
AllWindowedStream<T,W> |
AllWindowedStream.sideOutputLateData(OutputTag<T> outputTag)
Send late arriving data to the side output identified by the given
OutputTag . |
KeyedStream.IntervalJoined<IN1,IN2,KEY> |
KeyedStream.IntervalJoined.sideOutputLeftLateData(OutputTag<IN1> outputTag)
Send late arriving left-side data to the side output identified by the given
OutputTag . |
KeyedStream.IntervalJoined<IN1,IN2,KEY> |
KeyedStream.IntervalJoined.sideOutputRightLateData(OutputTag<IN2> outputTag)
Send late arriving right-side data to the side output identified by the given
OutputTag . |
Modifier and Type | Method and Description |
---|---|
abstract <X> void |
ProcessFunction.Context.output(OutputTag<X> outputTag,
X value)
Emits a record to the side output identified by the
OutputTag . |
abstract <X> void |
KeyedProcessFunction.Context.output(OutputTag<X> outputTag,
X value)
Emits a record to the side output identified by the
OutputTag . |
Modifier and Type | Method and Description |
---|---|
abstract <X> void |
KeyedCoProcessFunction.Context.output(OutputTag<X> outputTag,
X value)
Emits a record to the side output identified by the
OutputTag . |
abstract <X> void |
CoProcessFunction.Context.output(OutputTag<X> outputTag,
X value)
Emits a record to the side output identified by the
OutputTag . |
abstract <X> void |
ProcessJoinFunction.Context.output(OutputTag<X> outputTag,
X value)
Emits a record to the side output identified by the
OutputTag . |
Modifier and Type | Method and Description |
---|---|
<X> void |
InternalProcessApplyWindowContext.output(OutputTag<X> outputTag,
X value) |
<X> void |
InternalProcessApplyAllWindowContext.output(OutputTag<X> outputTag,
X value) |
abstract <X> void |
ProcessWindowFunction.Context.output(OutputTag<X> outputTag,
X value)
Emits a record to the side output identified by the
OutputTag . |
abstract <X> void |
ProcessAllWindowFunction.Context.output(OutputTag<X> outputTag,
X value)
Emits a record to the side output identified by the
OutputTag . |
Modifier and Type | Method and Description |
---|---|
OutputTag |
StreamEdge.getOutputTag() |
OutputTag<?> |
NonChainedOutput.getOutputTag() |
Modifier and Type | Method and Description |
---|---|
void |
StreamGraph.addVirtualSideOutputNode(Integer originalId,
Integer virtualId,
OutputTag outputTag)
Adds a new virtual node that is used to connect a downstream vertex to only the outputs with
the selected side-output
OutputTag . |
<T> TypeSerializer<T> |
StreamConfig.getTypeSerializerSideOut(OutputTag<?> outputTag,
ClassLoader cl) |
void |
StreamConfig.setTypeSerializerSideOut(OutputTag<?> outputTag,
TypeSerializer<?> serializer) |
Constructor and Description |
---|
NonChainedOutput(boolean supportsUnalignedCheckpoints,
int sourceNodeId,
int consumerParallelism,
int consumerMaxParallelism,
long bufferTimeout,
boolean isPersistentDataSet,
IntermediateDataSetID dataSetId,
OutputTag<?> outputTag,
StreamPartitioner<?> partitioner,
ResultPartitionType partitionType) |
StreamEdge(StreamNode sourceVertex,
StreamNode targetVertex,
int typeNumber,
long bufferTimeout,
StreamPartitioner<?> outputPartitioner,
OutputTag outputTag,
StreamExchangeMode exchangeMode,
int uniqueId,
IntermediateDataSetID intermediateDatasetId) |
StreamEdge(StreamNode sourceVertex,
StreamNode targetVertex,
int typeNumber,
StreamPartitioner<?> outputPartitioner,
OutputTag outputTag) |
StreamEdge(StreamNode sourceVertex,
StreamNode targetVertex,
int typeNumber,
StreamPartitioner<?> outputPartitioner,
OutputTag outputTag,
StreamExchangeMode exchangeMode,
int uniqueId,
IntermediateDataSetID intermediateDatasetId) |
Modifier and Type | Method and Description |
---|---|
<X> void |
Output.collect(OutputTag<X> outputTag,
StreamRecord<X> record)
Emits a record to the side output identified by the given
OutputTag . |
<X> void |
TimestampedCollector.collect(OutputTag<X> outputTag,
StreamRecord<X> record) |
<X> void |
CountingOutput.collect(OutputTag<X> outputTag,
StreamRecord<X> record) |
Constructor and Description |
---|
IntervalJoinOperator(long lowerBound,
long upperBound,
boolean lowerBoundInclusive,
boolean upperBoundInclusive,
OutputTag<T1> leftLateDataOutputTag,
OutputTag<T2> rightLateDataOutputTag,
TypeSerializer<T1> leftTypeSerializer,
TypeSerializer<T2> rightTypeSerializer,
ProcessJoinFunction<T1,T2,OUT> udf)
Creates a new IntervalJoinOperator.
|
IntervalJoinOperator(long lowerBound,
long upperBound,
boolean lowerBoundInclusive,
boolean upperBoundInclusive,
OutputTag<T1> leftLateDataOutputTag,
OutputTag<T2> rightLateDataOutputTag,
TypeSerializer<T1> leftTypeSerializer,
TypeSerializer<T2> rightTypeSerializer,
ProcessJoinFunction<T1,T2,OUT> udf)
Creates a new IntervalJoinOperator.
|
Modifier and Type | Method and Description |
---|---|
Collection<OutputTag<?>> |
DataStreamPythonFunctionOperator.getSideOutputTags()
Gets the
OutputTag s belongs to the operator. |
Modifier and Type | Method and Description |
---|---|
void |
DataStreamPythonFunctionOperator.addSideOutputTags(Collection<OutputTag<?>> outputTags)
Add a collection of
OutputTag s to the operator. |
Modifier and Type | Method and Description |
---|---|
Collection<OutputTag<?>> |
AbstractEmbeddedDataStreamPythonFunctionOperator.getSideOutputTags() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractEmbeddedDataStreamPythonFunctionOperator.addSideOutputTags(Collection<OutputTag<?>> outputTags) |
Modifier and Type | Method and Description |
---|---|
protected OutputTag<?> |
AbstractExternalDataStreamPythonFunctionOperator.getOutputTagById(String id) |
Modifier and Type | Method and Description |
---|---|
Collection<OutputTag<?>> |
AbstractExternalDataStreamPythonFunctionOperator.getSideOutputTags() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractExternalDataStreamPythonFunctionOperator.addSideOutputTags(Collection<OutputTag<?>> outputTags) |
Modifier and Type | Method and Description |
---|---|
<X> void |
RunnerOutputCollector.collect(OutputTag<X> outputTag,
Row runnerOutput) |
Modifier and Type | Method and Description |
---|---|
OutputTag<T> |
SideOutputTransformation.getOutputTag() |
Constructor and Description |
---|
SideOutputTransformation(Transformation<?> input,
OutputTag<T> tag) |
Modifier and Type | Method and Description |
---|---|
Collection<OutputTag<?>> |
DelegateOperatorTransformation.DelegateOperator.getSideOutputTags() |
Modifier and Type | Method and Description |
---|---|
void |
DelegateOperatorTransformation.DelegateOperator.addSideOutputTags(Collection<OutputTag<?>> outputTags) |
Modifier and Type | Method and Description |
---|---|
<X> void |
RecordWriterOutput.collect(OutputTag<X> outputTag,
StreamRecord<X> record) |
<X> boolean |
RecordWriterOutput.collectAndCheckIfChained(OutputTag<X> outputTag,
StreamRecord<X> record) |
Constructor and Description |
---|
RecordWriterOutput(RecordWriter<SerializationDelegate<StreamRecord<OUT>>> recordWriter,
TypeSerializer<OUT> outSerializer,
OutputTag outputTag,
boolean supportsUnalignedCheckpoints) |
Modifier and Type | Field and Description |
---|---|
protected OutputTag<IN> |
WindowOperator.lateDataOutputTag
OutputTag to use for late arriving events. |
Modifier and Type | Method and Description |
---|---|
<X> void |
WindowOperator.WindowContext.output(OutputTag<X> outputTag,
X value) |
void |
WindowOperatorBuilder.sideOutputLateData(OutputTag<T> outputTag) |
Constructor and Description |
---|
EvictingWindowOperator(WindowAssigner<? super IN,W> windowAssigner,
TypeSerializer<W> windowSerializer,
KeySelector<IN,K> keySelector,
TypeSerializer<K> keySerializer,
StateDescriptor<? extends ListState<StreamRecord<IN>>,?> windowStateDescriptor,
InternalWindowFunction<Iterable<IN>,OUT,K,W> windowFunction,
Trigger<? super IN,? super W> trigger,
Evictor<? super IN,? super W> evictor,
long allowedLateness,
OutputTag<IN> lateDataOutputTag) |
WindowOperator(WindowAssigner<? super IN,W> windowAssigner,
TypeSerializer<W> windowSerializer,
KeySelector<IN,K> keySelector,
TypeSerializer<K> keySerializer,
StateDescriptor<? extends AppendingState<IN,ACC>,?> windowStateDescriptor,
InternalWindowFunction<ACC,OUT,K,W> windowFunction,
Trigger<? super IN,? super W> trigger,
long allowedLateness,
OutputTag<IN> lateDataOutputTag)
Creates a new
WindowOperator based on the given policies and user functions. |
Modifier and Type | Method and Description |
---|---|
<X> void |
InternalWindowFunction.InternalWindowContext.output(OutputTag<X> outputTag,
X value) |
<X> void |
InternalProcessAllWindowContext.output(OutputTag<X> outputTag,
X value) |
<X> void |
InternalProcessWindowContext.output(OutputTag<X> outputTag,
X value) |
Modifier and Type | Method and Description |
---|---|
<X> void |
FinishedOnRestoreMainOperatorOutput.collect(OutputTag<X> outputTag,
StreamRecord<X> record) |
<X> boolean |
OutputWithChainingCheck.collectAndCheckIfChained(OutputTag<X> outputTag,
StreamRecord<X> record) |
Modifier and Type | Method and Description |
---|---|
<X> void |
CopyingSecondInputOfTwoInputStreamOperatorOutput.collect(OutputTag<X> outputTag,
StreamRecord<X> record) |
<X> void |
SecondInputOfTwoInputStreamOperatorOutput.collect(OutputTag<X> outputTag,
StreamRecord<X> record) |
<X> void |
CopyingBroadcastingOutput.collect(OutputTag<X> outputTag,
StreamRecord<X> record) |
<X> void |
BroadcastingOutput.collect(OutputTag<X> outputTag,
StreamRecord<X> record) |
<X> void |
FirstInputOfTwoInputStreamOperatorOutput.collect(OutputTag<X> outputTag,
StreamRecord<X> record) |
<X> void |
OneInputStreamOperatorOutput.collect(OutputTag<X> outputTag,
StreamRecord<X> record) |
Modifier and Type | Method and Description |
---|---|
static boolean |
OutputTag.isResponsibleFor(OutputTag<?> owner,
OutputTag<?> other) |
static boolean |
OutputTag.isResponsibleFor(OutputTag<?> owner,
OutputTag<?> other) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.