Package | Description |
---|---|
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
Modifier and Type | Method and Description |
---|---|
OperatorEventDispatcher |
StreamOperatorParameters.getOperatorEventDispatcher() |
Modifier and Type | Method and Description |
---|---|
static <OUT,OP extends StreamOperator<OUT>> |
StreamOperatorFactoryUtil.createOperator(StreamOperatorFactory<OUT> operatorFactory,
StreamTask<OUT,?> containingTask,
StreamConfig configuration,
Output<StreamRecord<OUT>> output,
OperatorEventDispatcher operatorEventDispatcher)
Creates a new operator using a factory and makes sure that all special factory traits are
properly handled.
|
Constructor and Description |
---|
StreamOperatorParameters(StreamTask<?,?> containingTask,
StreamConfig config,
Output<StreamRecord<OUT>> output,
Supplier<ProcessingTimeService> processingTimeServiceFactory,
OperatorEventDispatcher operatorEventDispatcher,
MailboxExecutor mailboxExecutor) |
Modifier and Type | Class and Description |
---|---|
class |
OperatorEventDispatcherImpl
An implementation of the
OperatorEventDispatcher . |
Modifier and Type | Method and Description |
---|---|
OperatorEventDispatcher |
OperatorChain.getOperatorEventDispatcher() |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.