Uses of Class
org.apache.flink.streaming.api.graph.StreamConfig
-
-
Uses of StreamConfig in org.apache.flink.runtime.asyncprocessing.operators
Methods in org.apache.flink.runtime.asyncprocessing.operators with parameters of type StreamConfig Modifier and Type Method Description protected voidAbstractAsyncStateUdfStreamOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output) -
Uses of StreamConfig in org.apache.flink.runtime.asyncprocessing.operators.windowing
Methods in org.apache.flink.runtime.asyncprocessing.operators.windowing with parameters of type StreamConfig Modifier and Type Method Description voidAsyncWindowOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output) -
Uses of StreamConfig in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return types with arguments of type StreamConfig Modifier and Type Method Description CompletableFuture<StreamConfig>StreamConfig. getSerializationFuture()Map<Integer,StreamConfig>StreamConfig. getTransitiveChainedTaskConfigs(ClassLoader cl)Map<Integer,StreamConfig>StreamConfig. getTransitiveChainedTaskConfigsWithSelf(ClassLoader cl)CompletableFuture<StreamConfig>StreamConfig. triggerSerializationAndReturnFuture(Executor ioExecutor)Trigger the object config serialization and return the completable future.Methods in org.apache.flink.streaming.api.graph with parameters of type StreamConfig Modifier and Type Method Description static voidStreamingJobGraphGenerator. setOperatorChainedOutputsConfig(StreamConfig config, List<StreamEdge> chainableOutputs, JobVertexBuildContext jobVertexBuildContext)static voidStreamingJobGraphGenerator. setOperatorConfig(Integer vertexId, StreamConfig config, OperatorChainInfo chainInfo, JobVertexBuildContext jobVertexBuildContext)Method parameters in org.apache.flink.streaming.api.graph with type arguments of type StreamConfig Modifier and Type Method Description voidStreamConfig. setAndSerializeTransitiveChainedTaskConfigs(Map<Integer,StreamConfig> chainedTaskConfigs)voidStreamConfig. setTransitiveChainedTaskConfigs(Map<Integer,StreamConfig> chainedTaskConfigs) -
Uses of StreamConfig in org.apache.flink.streaming.api.graph.util
Methods in org.apache.flink.streaming.api.graph.util that return StreamConfig Modifier and Type Method Description StreamConfigChainedSourceInfo. getOperatorConfig()StreamConfigOperatorInfo. getVertexConfig()Methods in org.apache.flink.streaming.api.graph.util that return types with arguments of type StreamConfig Modifier and Type Method Description Map<Integer,Map<Integer,StreamConfig>>JobVertexBuildContext. getChainedConfigs()Map<Integer,StreamConfig>JobVertexBuildContext. getOrCreateChainedConfig(Integer streamNodeId)Methods in org.apache.flink.streaming.api.graph.util with parameters of type StreamConfig Modifier and Type Method Description voidOperatorInfo. setVertexConfig(StreamConfig vertexConfig)Constructors in org.apache.flink.streaming.api.graph.util with parameters of type StreamConfig Constructor Description ChainedSourceInfo(StreamConfig operatorConfig, StreamConfig.SourceInputConfig inputConfig) -
Uses of StreamConfig in org.apache.flink.streaming.api.operators
Fields in org.apache.flink.streaming.api.operators declared as StreamConfig Modifier and Type Field Description protected StreamConfigAbstractStreamOperator. configprotected StreamConfigAbstractStreamOperatorV2. configMethods in org.apache.flink.streaming.api.operators that return StreamConfig Modifier and Type Method Description StreamConfigAbstractStreamOperator. getOperatorConfig()StreamConfigAbstractStreamOperatorV2. getOperatorConfig()StreamConfigStreamOperatorParameters. getStreamConfig()Methods in org.apache.flink.streaming.api.operators with parameters of type StreamConfig Modifier and Type Method Description static <OUT,OP extends StreamOperator<OUT>>
org.apache.flink.api.java.tuple.Tuple2<OP,Optional<ProcessingTimeService>>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.protected voidAbstractStreamOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)protected voidAbstractUdfStreamOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)protected voidSourceOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)static <OUT> voidStreamOperatorUtils. setupStreamOperator(AbstractStreamOperator<OUT> operator, StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)Constructors in org.apache.flink.streaming.api.operators with parameters of type StreamConfig Constructor Description StreamOperatorParameters(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output, Supplier<ProcessingTimeService> processingTimeServiceFactory, OperatorEventDispatcher operatorEventDispatcher, org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor) -
Uses of StreamConfig in org.apache.flink.streaming.api.operators.sortpartition
Methods in org.apache.flink.streaming.api.operators.sortpartition with parameters of type StreamConfig Modifier and Type Method Description protected voidKeyedSortPartitionOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<INPUT>> output)protected voidSortPartitionOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<INPUT>> output) -
Uses of StreamConfig in org.apache.flink.streaming.runtime.io
Methods in org.apache.flink.streaming.runtime.io with parameters of type StreamConfig Modifier and Type Method Description static StreamMultipleInputProcessorStreamMultipleInputProcessorFactory. create(TaskInvokable ownerTask, CheckpointedInputGate[] checkpointedInputGates, StreamConfig.InputConfig[] configuredInputs, IOManager ioManager, MemoryManager memoryManager, TaskIOMetricGroup ioMetricGroup, org.apache.flink.metrics.Counter mainOperatorRecordsIn, MultipleInputStreamOperator<?> mainOperator, WatermarkGauge[] inputWatermarkGauges, StreamConfig streamConfig, org.apache.flink.configuration.Configuration taskManagerConfig, org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.api.common.ExecutionConfig executionConfig, ClassLoader userClassloader, OperatorChain<?,?> operatorChain, InflightDataRescalingDescriptor inflightDataRescalingDescriptor, Function<Integer,StreamPartitioner<?>> gatePartitioners, org.apache.flink.api.common.TaskInfo taskInfo, StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords)static <IN1,IN2>
StreamMultipleInputProcessorStreamTwoInputProcessorFactory. create(TaskInvokable ownerTask, CheckpointedInputGate[] checkpointedInputGates, IOManager ioManager, MemoryManager memoryManager, TaskIOMetricGroup taskIOMetricGroup, TwoInputStreamOperator<IN1,IN2,?> streamOperator, WatermarkGauge input1WatermarkGauge, WatermarkGauge input2WatermarkGauge, OperatorChain<?,?> operatorChain, StreamConfig streamConfig, org.apache.flink.configuration.Configuration taskManagerConfig, org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.api.common.ExecutionConfig executionConfig, ClassLoader userClassloader, org.apache.flink.metrics.Counter numRecordsIn, InflightDataRescalingDescriptor inflightDataRescalingDescriptor, Function<Integer,StreamPartitioner<?>> gatePartitioners, org.apache.flink.api.common.TaskInfo taskInfo, StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords) -
Uses of StreamConfig in org.apache.flink.streaming.runtime.io.checkpointing
Methods in org.apache.flink.streaming.runtime.io.checkpointing with parameters of type StreamConfig Modifier and Type Method Description static CheckpointBarrierHandlerInputProcessorUtil. createCheckpointBarrierHandler(CheckpointableTask toNotifyOnCheckpoint, StreamConfig config, SubtaskCheckpointCoordinator checkpointCoordinator, String taskName, List<IndexedInputGate>[] inputGates, List<StreamTaskSourceInput<?>> sourceInputs, org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, TimerService timerService)static CheckpointedInputGate[]InputProcessorUtil. createCheckpointedMultipleInputGate(org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, List<IndexedInputGate>[] inputGates, TaskIOMetricGroup taskIOMetricGroup, CheckpointBarrierHandler barrierHandler, StreamConfig config) -
Uses of StreamConfig in org.apache.flink.streaming.runtime.operators.sink
Methods in org.apache.flink.streaming.runtime.operators.sink with parameters of type StreamConfig Modifier and Type Method Description protected voidGlobalCommitterOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<Void>> output) -
Uses of StreamConfig in org.apache.flink.streaming.runtime.operators.windowing
Methods in org.apache.flink.streaming.runtime.operators.windowing with parameters of type StreamConfig Modifier and Type Method Description voidWindowOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output) -
Uses of StreamConfig in org.apache.flink.streaming.runtime.tasks
Fields in org.apache.flink.streaming.runtime.tasks declared as StreamConfig Modifier and Type Field Description protected StreamConfigStreamTask. configurationThe configuration of this streaming task.Methods in org.apache.flink.streaming.runtime.tasks that return StreamConfig Modifier and Type Method Description StreamConfigStreamTask. getConfiguration()Methods in org.apache.flink.streaming.runtime.tasks with parameters of type StreamConfig Modifier and Type Method Description static <OUT> RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>StreamTask. createRecordWriterDelegate(StreamConfig configuration, Environment environment)
-