Uses of Class
org.apache.flink.runtime.jobgraph.OperatorID
-
-
Uses of OperatorID in org.apache.flink.runtime
Methods in org.apache.flink.runtime that return OperatorID Modifier and Type Method Description OperatorIDOperatorIDPair. getGeneratedOperatorID()Methods in org.apache.flink.runtime that return types with arguments of type OperatorID Modifier and Type Method Description Optional<OperatorID>OperatorIDPair. getUserDefinedOperatorID()Methods in org.apache.flink.runtime with parameters of type OperatorID Modifier and Type Method Description static OperatorIDPairOperatorIDPair. generatedIDOnly(OperatorID generatedOperatorID)static OperatorIDPairOperatorIDPair. of(OperatorID generatedOperatorID, OperatorID userDefinedOperatorID, String operatorName, String operatorUid) -
Uses of OperatorID in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return OperatorID Modifier and Type Method Description OperatorIDOperatorState. getOperatorID()Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type OperatorID Modifier and Type Method Description Map<OperatorID,OperatorState>CompletedCheckpoint. getOperatorStates()Map<OperatorID,OperatorState>PendingCheckpoint. getOperatorStates()Set<Map.Entry<OperatorID,OperatorSubtaskState>>TaskStateSnapshot. getSubtaskStateMappings()Returns the set of all mappings from operator id to the corresponding subtask state.Methods in org.apache.flink.runtime.checkpoint with parameters of type OperatorID Modifier and Type Method Description static <T> Map<OperatorInstanceID,List<T>>StateAssignmentOperation. applyRepartitioner(OperatorID operatorID, OperatorStateRepartitioner<T> opStateRepartitioner, List<List<T>> chainOpParallelStates, int oldParallelism, int newParallelism)OperatorStateOperatorState. copyWithNewIDs(String newOperatorUid, OperatorID newOperatorId)OperatorSubtaskStateTaskStateSnapshot. getSubtaskStateByOperatorID(OperatorID operatorID)Returns the subtask state for the given operator id (or null if not contained).OperatorSubtaskStateTaskStateSnapshot. putSubtaskStateByOperatorID(OperatorID operatorID, OperatorSubtaskState state)Maps the given operator id to the given subtask state.voidCheckpointCoordinator. setIsProcessingBacklog(OperatorID operatorID, boolean isProcessingBacklog)Reports whether a source operator is currently processing backlog.Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type OperatorID Modifier and Type Method Description voidDefaultCheckpointPlan. fulfillFinishedTaskStatus(Map<OperatorID,OperatorState> operatorStates)voidFinishedTaskStateProvider. fulfillFinishedTaskStatus(Map<OperatorID,OperatorState> operatorStates)Fulfills the state for the finished subtasks and operators to indicate they are finished.static <T extends StateObject>
voidStateAssignmentOperation. reDistributePartitionableStates(Map<OperatorID,OperatorState> oldOperatorStates, int newParallelism, Function<OperatorSubtaskState,StateObjectCollection<T>> extractHandle, OperatorStateRepartitioner<T> stateRepartitioner, Map<OperatorInstanceID,List<T>> result)Constructors in org.apache.flink.runtime.checkpoint with parameters of type OperatorID Constructor Description FullyFinishedOperatorState(String operatorName, String operatorUid, OperatorID operatorID, int parallelism, int maxParallelism)OperatorState(String operatorName, String operatorUid, OperatorID operatorID, int parallelism, int maxParallelism)Constructor parameters in org.apache.flink.runtime.checkpoint with type arguments of type OperatorID Constructor Description CheckpointCoordinator(org.apache.flink.api.common.JobID job, CheckpointCoordinatorConfiguration chkConfig, Collection<OperatorCoordinatorCheckpointContext> coordinatorsToCheckpoint, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore completedCheckpointStore, CheckpointStorage checkpointStorage, Executor executor, CheckpointsCleaner checkpointsCleaner, org.apache.flink.util.concurrent.ScheduledExecutor timer, CheckpointFailureManager failureManager, CheckpointPlanCalculator checkpointPlanCalculator, org.apache.flink.util.clock.Clock clock, CheckpointStatsTracker statsTracker, BiFunction<Set<ExecutionJobVertex>,Map<OperatorID,OperatorState>,VertexFinishedStateChecker> vertexFinishedStateCheckerFactory)CompletedCheckpoint(org.apache.flink.api.common.JobID job, long checkpointID, long timestamp, long completionTimestamp, Map<OperatorID,OperatorState> operatorStates, Collection<MasterState> masterHookStates, CheckpointProperties props, CompletedCheckpointStorageLocation storageLocation, CompletedCheckpointStats completedCheckpointStats)CompletedCheckpoint(org.apache.flink.api.common.JobID job, long checkpointID, long timestamp, long completionTimestamp, Map<OperatorID,OperatorState> operatorStates, Collection<MasterState> masterHookStates, CheckpointProperties props, CompletedCheckpointStorageLocation storageLocation, CompletedCheckpointStats completedCheckpointStats, CheckpointProperties restoredProps)PendingCheckpoint(org.apache.flink.api.common.JobID jobId, long checkpointId, long checkpointTimestamp, CheckpointPlan checkpointPlan, Collection<OperatorID> operatorCoordinatorsToConfirm, Collection<String> masterStateIdentifiers, CheckpointProperties props, CompletableFuture<CompletedCheckpoint> onCompletionPromise, PendingCheckpointStats pendingCheckpointStats, CompletableFuture<Void> masterTriggerCompletionPromise)StateAssignmentOperation(long restoreCheckpointId, Set<ExecutionJobVertex> tasks, Map<OperatorID,OperatorState> operatorStates, boolean allowNonRestoredState)TaskStateSnapshot(Map<OperatorID,OperatorSubtaskState> subtaskStatesByOperatorID)VertexFinishedStateChecker(Set<ExecutionJobVertex> vertices, Map<OperatorID,OperatorState> operatorStates) -
Uses of OperatorID in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph with parameters of type OperatorID Modifier and Type Method Description CompletableFuture<Acknowledge>Execution. sendOperatorEvent(OperatorID operatorId, org.apache.flink.util.SerializedValue<OperatorEvent> event)Sends the operator event to the Task on the Task Executor. -
Uses of OperatorID in org.apache.flink.runtime.jobgraph
Methods in org.apache.flink.runtime.jobgraph that return OperatorID Modifier and Type Method Description static OperatorIDOperatorID. fromJobVertexID(JobVertexID id)OperatorIDOperatorInstanceID. getOperatorId()Methods in org.apache.flink.runtime.jobgraph that return types with arguments of type OperatorID Modifier and Type Method Description Map<OperatorID,org.apache.flink.api.common.operators.util.UserCodeWrapper<? extends org.apache.flink.api.common.io.InputFormat<?,?>>>InputOutputFormatContainer.FormatUserCodeTable. getInputFormats()Map<OperatorID,org.apache.flink.api.common.operators.util.UserCodeWrapper<? extends org.apache.flink.api.common.io.InputFormat<?,?>>>InputOutputFormatContainer. getInputFormats()Map<OperatorID,org.apache.flink.api.common.operators.util.UserCodeWrapper<? extends org.apache.flink.api.common.io.OutputFormat<?>>>InputOutputFormatContainer.FormatUserCodeTable. getOutputFormats()Map<OperatorID,org.apache.flink.api.common.operators.util.UserCodeWrapper<? extends org.apache.flink.api.common.io.OutputFormat<?>>>InputOutputFormatContainer. getOutputFormats()<OT,T extends org.apache.flink.core.io.InputSplit>
org.apache.commons.lang3.tuple.Pair<OperatorID,org.apache.flink.api.common.io.InputFormat<OT,T>>InputOutputFormatContainer. getUniqueInputFormat()<IT> org.apache.commons.lang3.tuple.Pair<OperatorID,org.apache.flink.api.common.io.OutputFormat<IT>>InputOutputFormatContainer. getUniqueOutputFormat()Methods in org.apache.flink.runtime.jobgraph with parameters of type OperatorID Modifier and Type Method Description InputOutputFormatContainerInputOutputFormatContainer. addInputFormat(OperatorID operatorId, org.apache.flink.api.common.io.InputFormat<?,?> inputFormat)InputOutputFormatContainerInputOutputFormatContainer. addInputFormat(OperatorID operatorId, org.apache.flink.api.common.operators.util.UserCodeWrapper<? extends org.apache.flink.api.common.io.InputFormat<?,?>> wrapper)voidInputOutputFormatContainer.FormatUserCodeTable. addInputFormat(OperatorID operatorId, org.apache.flink.api.common.operators.util.UserCodeWrapper<? extends org.apache.flink.api.common.io.InputFormat<?,?>> wrapper)InputOutputFormatContainerInputOutputFormatContainer. addOutputFormat(OperatorID operatorId, org.apache.flink.api.common.io.OutputFormat<?> outputFormat)InputOutputFormatContainerInputOutputFormatContainer. addOutputFormat(OperatorID operatorId, org.apache.flink.api.common.operators.util.UserCodeWrapper<? extends org.apache.flink.api.common.io.OutputFormat<?>> wrapper)voidInputOutputFormatContainer.FormatUserCodeTable. addOutputFormat(OperatorID operatorId, org.apache.flink.api.common.operators.util.UserCodeWrapper<? extends org.apache.flink.api.common.io.OutputFormat<?>> wrapper)InputOutputFormatContainerInputOutputFormatContainer. addParameters(OperatorID operatorId, String key, String value)InputOutputFormatContainerInputOutputFormatContainer. addParameters(OperatorID operatorId, org.apache.flink.configuration.Configuration parameters)StringInputOutputFormatVertex. getFormatDescription(OperatorID operatorID)org.apache.flink.configuration.ConfigurationInputOutputFormatContainer. getParameters(OperatorID operatorId)static OperatorInstanceIDOperatorInstanceID. of(int subtaskId, OperatorID operatorID)voidInputOutputFormatVertex. setFormatDescription(OperatorID operatorID, String formatDescription)Constructors in org.apache.flink.runtime.jobgraph with parameters of type OperatorID Constructor Description OperatorInstanceID(int subtaskId, OperatorID operatorId) -
Uses of OperatorID in org.apache.flink.runtime.jobgraph.tasks
Methods in org.apache.flink.runtime.jobgraph.tasks with parameters of type OperatorID Modifier and Type Method Description voidAbstractInvokable. dispatchOperatorEvent(OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> event)voidCoordinatedTask. dispatchOperatorEvent(OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> event)voidTaskOperatorEventGateway. sendOperatorEventToCoordinator(OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> event)Sends an event from the operator (identified by the given operator ID) to the operator coordinator (identified by the same ID).CompletableFuture<CoordinationResponse>TaskOperatorEventGateway. sendRequestToCoordinator(OperatorID operator, org.apache.flink.util.SerializedValue<CoordinationRequest> request)Sends a request from current operator to a specified operator coordinator which is identified by the given operator ID and return the response. -
Uses of OperatorID in org.apache.flink.runtime.jobmanager.slots
Methods in org.apache.flink.runtime.jobmanager.slots with parameters of type OperatorID Modifier and Type Method Description CompletableFuture<Acknowledge>TaskManagerGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt) -
Uses of OperatorID in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster with parameters of type OperatorID Modifier and Type Method Description CompletableFuture<CoordinationResponse>JobMaster. deliverCoordinationRequestToCoordinator(OperatorID operatorId, org.apache.flink.util.SerializedValue<CoordinationRequest> serializedRequest, Duration timeout)CompletableFuture<CoordinationResponse>JobMasterGateway. deliverCoordinationRequestToCoordinator(OperatorID operatorId, org.apache.flink.util.SerializedValue<CoordinationRequest> serializedRequest, Duration timeout)Deliver a coordination request to a specified coordinator and return the response.CompletableFuture<Acknowledge>JobMaster. sendOperatorEventToCoordinator(ExecutionAttemptID task, OperatorID operatorID, org.apache.flink.util.SerializedValue<OperatorEvent> serializedEvent)CompletableFuture<Acknowledge>JobMasterOperatorEventGateway. sendOperatorEventToCoordinator(ExecutionAttemptID task, OperatorID operatorID, org.apache.flink.util.SerializedValue<OperatorEvent> event)CompletableFuture<Acknowledge>RpcTaskManagerGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)CompletableFuture<CoordinationResponse>JobMaster. sendRequestToCoordinator(OperatorID operatorID, org.apache.flink.util.SerializedValue<CoordinationRequest> serializedRequest)CompletableFuture<CoordinationResponse>JobMasterOperatorEventGateway. sendRequestToCoordinator(OperatorID operatorID, org.apache.flink.util.SerializedValue<CoordinationRequest> request) -
Uses of OperatorID in org.apache.flink.runtime.jobmaster.event
Methods in org.apache.flink.runtime.jobmaster.event that return types with arguments of type OperatorID Modifier and Type Method Description Map<OperatorID,CompletableFuture<byte[]>>ExecutionVertexFinishedEvent. getOperatorCoordinatorSnapshotFutures()Constructor parameters in org.apache.flink.runtime.jobmaster.event with type arguments of type OperatorID Constructor Description ExecutionVertexFinishedEvent(ExecutionAttemptID executionAttemptId, TaskManagerLocation location, Map<OperatorID,CompletableFuture<byte[]>> operatorCoordinatorSnapshotFutures, CompletableFuture<ShuffleMasterSnapshot> shuffleMasterSnapshotFuture, IOMetrics ioMetrics, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> userAccumulators) -
Uses of OperatorID in org.apache.flink.runtime.metrics.groups
Methods in org.apache.flink.runtime.metrics.groups with parameters of type OperatorID Modifier and Type Method Description JobManagerOperatorMetricGroupJobManagerJobMetricGroup. getOrAddOperator(org.apache.flink.util.AbstractID vertexId, String taskName, OperatorID operatorID, String operatorName)InternalOperatorMetricGroupTaskMetricGroup. getOrAddOperator(OperatorID operatorID, String operatorName)JobManagerOperatorMetricGroupUnregisteredMetricGroups.UnregisteredJobManagerJobMetricGroup. getOrAddOperator(org.apache.flink.util.AbstractID vertexId, String taskName, OperatorID operatorID, String operatorName)InternalOperatorMetricGroupUnregisteredMetricGroups.UnregisteredTaskMetricGroup. getOrAddOperator(OperatorID operatorID, String name)Constructors in org.apache.flink.runtime.metrics.groups with parameters of type OperatorID Constructor Description JobManagerOperatorMetricGroup(MetricRegistry registry, JobManagerJobMetricGroup parent, org.apache.flink.util.AbstractID vertexId, String taskName, OperatorID operatorID, String operatorName) -
Uses of OperatorID in org.apache.flink.runtime.metrics.scope
Methods in org.apache.flink.runtime.metrics.scope with parameters of type OperatorID Modifier and Type Method Description String[]JobManagerOperatorScopeFormat. formatScope(JobManagerJobMetricGroup parent, org.apache.flink.util.AbstractID vertexId, String taskName, OperatorID operatorID, String operatorName)String[]OperatorScopeFormat. formatScope(TaskMetricGroup parent, OperatorID operatorID, String operatorName) -
Uses of OperatorID in org.apache.flink.runtime.operators.coordination
Methods in org.apache.flink.runtime.operators.coordination that return OperatorID Modifier and Type Method Description OperatorIDOperatorCoordinator.Context. getOperatorId()Gets the ID of the operator to which the coordinator belongs.OperatorIDOperatorCoordinator.Provider. getOperatorId()Gets the ID of the operator to which the coordinator belongs.OperatorIDRecreateOnResetOperatorCoordinator.Provider. getOperatorId()OperatorIDOperatorCoordinatorHolder. operatorId()OperatorIDOperatorInfo. operatorId()Methods in org.apache.flink.runtime.operators.coordination that return types with arguments of type OperatorID Modifier and Type Method Description static Collection<OperatorID>OperatorInfo. getIds(Collection<? extends OperatorInfo> infos)Methods in org.apache.flink.runtime.operators.coordination with parameters of type OperatorID Modifier and Type Method Description OperatorEventGatewayOperatorEventDispatcher. getOperatorEventGateway(OperatorID operatorId)Gets the gateway through which events can be passed to the OperatorCoordinator for the operator identified by the given OperatorID.voidOperatorEventDispatcher. registerEventHandler(OperatorID operator, OperatorEventHandler handler)Register a listener that is notified every time an OperatorEvent is sent from the OperatorCoordinator (of the operator with the given OperatorID) to this subtask.Constructors in org.apache.flink.runtime.operators.coordination with parameters of type OperatorID Constructor Description Provider(OperatorID operatorID) -
Uses of OperatorID in org.apache.flink.runtime.scheduler
Constructors in org.apache.flink.runtime.scheduler with parameters of type OperatorID Constructor Description CoordinatorNotExistException(OperatorID operator)CoordinatorNotExistException(OperatorID operator, String otherPossibleCause, boolean logException) -
Uses of OperatorID in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type OperatorID Modifier and Type Method Description CompletableFuture<CoordinationResponse>AdaptiveScheduler. deliverCoordinationRequestToCoordinator(OperatorID operator, CoordinationRequest request)voidAdaptiveScheduler. deliverOperatorEventToCoordinator(ExecutionAttemptID taskExecution, OperatorID operator, OperatorEvent evt) -
Uses of OperatorID in org.apache.flink.runtime.source.coordinator
Constructors in org.apache.flink.runtime.source.coordinator with parameters of type OperatorID Constructor Description SourceCoordinatorProvider(String operatorName, OperatorID operatorID, org.apache.flink.api.connector.source.Source<?,SplitT,?> source, int numWorkerThreads, org.apache.flink.api.common.eventtime.WatermarkAlignmentParams alignmentParams, String coordinatorListeningID)Construct theSourceCoordinatorProvider. -
Uses of OperatorID in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with parameters of type OperatorID Modifier and Type Method Description Optional<OperatorSubtaskState>TaskStateManager. getSubtaskJobManagerRestoredState(OperatorID operatorID)Get the restored state from jobManager which belongs to an operator running in the owning task.Optional<OperatorSubtaskState>TaskStateManagerImpl. getSubtaskJobManagerRestoredState(OperatorID operatorID)PrioritizedOperatorSubtaskStateTaskStateManager. prioritizedOperatorState(OperatorID operatorID)Returns means to restore previously reported state of an operator running in the owning task.PrioritizedOperatorSubtaskStateTaskStateManagerImpl. prioritizedOperatorState(OperatorID operatorID) -
Uses of OperatorID in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor with parameters of type OperatorID Modifier and Type Method Description CompletableFuture<Acknowledge>TaskExecutor. sendOperatorEventToTask(ExecutionAttemptID executionAttemptID, OperatorID operatorId, org.apache.flink.util.SerializedValue<OperatorEvent> evt)CompletableFuture<Acknowledge>TaskExecutorGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)CompletableFuture<Acknowledge>TaskExecutorGatewayDecoratorBase. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)CompletableFuture<Acknowledge>TaskExecutorOperatorEventGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)Sends an operator event to an operator in a task executed by the Task Manager (Task Executor). -
Uses of OperatorID in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc with parameters of type OperatorID Modifier and Type Method Description voidRpcTaskOperatorEventGateway. sendOperatorEventToCoordinator(OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> event)CompletableFuture<CoordinationResponse>RpcTaskOperatorEventGateway. sendRequestToCoordinator(OperatorID operator, org.apache.flink.util.SerializedValue<CoordinationRequest> request) -
Uses of OperatorID in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager with parameters of type OperatorID Modifier and Type Method Description voidTask. deliverOperatorEvent(OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)Dispatches an operator event to the invokable task. -
Uses of OperatorID in org.apache.flink.runtime.util
Constructors in org.apache.flink.runtime.util with parameters of type OperatorID Constructor Description OperatorSubtaskDescriptionText(OperatorID operatorId, String operatorClass, int subtaskIndex, int numberOfTasks) -
Uses of OperatorID in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return OperatorID Modifier and Type Method Description static OperatorIDStreamingJobGraphGenerator. generateOperatorID(String operatorUid)Creates an instance ofOperatorIDbased on the provided operator unique identifier (UID).OperatorIDStreamConfig. getOperatorID()Methods in org.apache.flink.streaming.api.graph with parameters of type OperatorID Modifier and Type Method Description Optional<OperatorCoordinator.Provider>StreamNode. getCoordinatorProvider(String operatorName, OperatorID operatorID)voidStreamConfig. setOperatorID(OperatorID operatorID) -
Uses of OperatorID in org.apache.flink.streaming.api.graph.util
Methods in org.apache.flink.streaming.api.graph.util that return OperatorID Modifier and Type Method Description OperatorIDOperatorChainInfo. addNodeToChain(int currentNodeId, String operatorName, JobVertexBuildContext jobVertexBuildContext)OperatorIDOperatorInfo. getOperatorId()Methods in org.apache.flink.streaming.api.graph.util with parameters of type OperatorID Modifier and Type Method Description OperatorInfoOperatorChainInfo. createAndGetOperatorInfo(Integer nodeId, OperatorID operatorId)Constructors in org.apache.flink.streaming.api.graph.util with parameters of type OperatorID Constructor Description OperatorInfo(OperatorID operatorId) -
Uses of OperatorID in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return OperatorID Modifier and Type Method Description OperatorIDAbstractStreamOperator. getOperatorID()OperatorIDAbstractStreamOperatorV2. getOperatorID()OperatorIDStreamOperator. getOperatorID()Methods in org.apache.flink.streaming.api.operators with parameters of type OperatorID Modifier and Type Method Description OperatorCoordinator.ProviderCoordinatedOperatorFactory. getCoordinatorProvider(String operatorName, OperatorID operatorID)Get the operator coordinator provider for this operator.OperatorCoordinator.ProviderSourceOperatorFactory. getCoordinatorProvider(String operatorName, OperatorID operatorID)StreamOperatorStateContextStreamTaskStateInitializer. streamOperatorStateContext(OperatorID operatorID, String operatorClassName, ProcessingTimeService processingTimeService, KeyContext keyContext, org.apache.flink.api.common.typeutils.TypeSerializer<?> keySerializer, org.apache.flink.core.fs.CloseableRegistry streamTaskCloseableRegistry, org.apache.flink.metrics.MetricGroup metricGroup, double managedMemoryFraction, boolean isUsingCustomRawKeyedState, boolean isAsyncState)Returns theStreamOperatorStateContextfor anAbstractStreamOperatorthat runs in the stream task that owns this manager.StreamOperatorStateContextStreamTaskStateInitializerImpl. streamOperatorStateContext(OperatorID operatorID, String operatorClassName, ProcessingTimeService processingTimeService, KeyContext keyContext, org.apache.flink.api.common.typeutils.TypeSerializer<?> keySerializer, org.apache.flink.core.fs.CloseableRegistry streamTaskCloseableRegistry, org.apache.flink.metrics.MetricGroup metricGroup, double managedMemoryFraction, boolean isUsingCustomRawKeyedState, boolean isAsyncState)Constructors in org.apache.flink.streaming.api.operators with parameters of type OperatorID Constructor Description StreamingRuntimeContext(Environment env, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> accumulators, org.apache.flink.metrics.groups.OperatorMetricGroup operatorMetricGroup, OperatorID operatorID, ProcessingTimeService processingTimeService, org.apache.flink.api.common.state.KeyedStateStore keyedStateStore, ExternalResourceInfoProvider externalResourceInfoProvider) -
Uses of OperatorID in org.apache.flink.streaming.api.operators.collect
Methods in org.apache.flink.streaming.api.operators.collect that return OperatorID Modifier and Type Method Description OperatorIDCollectSinkOperatorCoordinator.Provider. getOperatorId()Methods in org.apache.flink.streaming.api.operators.collect with parameters of type OperatorID Modifier and Type Method Description OperatorCoordinator.ProviderCollectSinkOperatorFactory. getCoordinatorProvider(String operatorName, OperatorID operatorID)Constructors in org.apache.flink.streaming.api.operators.collect with parameters of type OperatorID Constructor Description Provider(OperatorID operatorId, int socketTimeout) -
Uses of OperatorID in org.apache.flink.streaming.runtime.io
Methods in org.apache.flink.streaming.runtime.io that return OperatorID Modifier and Type Method Description OperatorIDStreamTaskSourceInput. getOperatorID() -
Uses of OperatorID in org.apache.flink.streaming.runtime.streamrecord
Methods in org.apache.flink.streaming.runtime.streamrecord that return OperatorID Modifier and Type Method Description OperatorIDLatencyMarker. getOperatorId()Constructors in org.apache.flink.streaming.runtime.streamrecord with parameters of type OperatorID Constructor Description LatencyMarker(long markedTime, OperatorID operatorId, int subtaskIndex)Creates a latency mark with the given timestamp. -
Uses of OperatorID in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks with parameters of type OperatorID Modifier and Type Method Description voidFinishedOperatorChain. dispatchOperatorEvent(OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> event)abstract voidOperatorChain. dispatchOperatorEvent(OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> event)voidRegularOperatorChain. dispatchOperatorEvent(OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> event)voidStreamTask. dispatchOperatorEvent(OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> event)OperatorEventGatewayOperatorEventDispatcherImpl. getOperatorEventGateway(OperatorID operatorId)voidOperatorEventDispatcherImpl. registerEventHandler(OperatorID operator, OperatorEventHandler handler)Method parameters in org.apache.flink.streaming.runtime.tasks with type arguments of type OperatorID Modifier and Type Method Description voidFinishedOperatorChain. snapshotState(Map<OperatorID,OperatorSnapshotFutures> operatorSnapshotsInProgress, CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions, Supplier<Boolean> isRunning, ChannelStateWriter.ChannelStateWriteResult channelStateWriteResult, CheckpointStreamFactory storage)abstract voidOperatorChain. snapshotState(Map<OperatorID,OperatorSnapshotFutures> operatorSnapshotsInProgress, CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions, Supplier<Boolean> isRunning, ChannelStateWriter.ChannelStateWriteResult channelStateWriteResult, CheckpointStreamFactory storage)voidRegularOperatorChain. snapshotState(Map<OperatorID,OperatorSnapshotFutures> operatorSnapshotsInProgress, CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions, Supplier<Boolean> isRunning, ChannelStateWriter.ChannelStateWriteResult channelStateWriteResult, CheckpointStreamFactory storage) -
Uses of OperatorID in org.apache.flink.streaming.util
Constructors in org.apache.flink.streaming.util with parameters of type OperatorID Constructor Description LatencyStats(org.apache.flink.metrics.MetricGroup metricGroup, int historySize, int subtaskIndex, OperatorID operatorID, LatencyStats.Granularity granularity)
-