Uses of Interface
org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
-
Uses of ShuffleEnvironment in org.apache.flink.runtime.io.network
Classes in org.apache.flink.runtime.io.network that implement ShuffleEnvironment Modifier and Type Class Description classNettyShuffleEnvironmentThe implementation ofShuffleEnvironmentbased on netty network communication, local memory and disk files. -
Uses of ShuffleEnvironment in org.apache.flink.runtime.io.network.partition
Constructors in org.apache.flink.runtime.io.network.partition with parameters of type ShuffleEnvironment Constructor Description TaskExecutorPartitionTrackerImpl(ShuffleEnvironment<?,?> shuffleEnvironment) -
Uses of ShuffleEnvironment in org.apache.flink.runtime.shuffle
Methods in org.apache.flink.runtime.shuffle that return ShuffleEnvironment Modifier and Type Method Description ShuffleEnvironment<P,G>ShuffleServiceFactory. createShuffleEnvironment(ShuffleEnvironmentContext shuffleEnvironmentContext)Factory method to create a specific localShuffleEnvironmentimplementation. -
Uses of ShuffleEnvironment in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return ShuffleEnvironment Modifier and Type Method Description ShuffleEnvironment<?,?>TaskManagerServices. getShuffleEnvironment() -
Uses of ShuffleEnvironment in org.apache.flink.runtime.taskmanager
Constructors in org.apache.flink.runtime.taskmanager with parameters of type ShuffleEnvironment Constructor Description Task(JobInformation jobInformation, TaskInformation taskInformation, ExecutionAttemptID executionAttemptID, AllocationID slotAllocationId, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors, MemoryManager memManager, SharedResources sharedResources, IOManager ioManager, ShuffleEnvironment<?,?> shuffleEnvironment, KvStateService kvStateService, BroadcastVariableManager bcVarManager, TaskEventDispatcher taskEventDispatcher, ExternalResourceInfoProvider externalResourceInfoProvider, TaskStateManager taskStateManager, TaskManagerActions taskManagerActions, InputSplitProvider inputSplitProvider, CheckpointResponder checkpointResponder, TaskOperatorEventGateway operatorCoordinatorEventGateway, GlobalAggregateManager aggregateManager, LibraryCacheManager.ClassLoaderHandle classLoaderHandle, FileCache fileCache, TaskManagerRuntimeInfo taskManagerConfig, TaskMetricGroup metricGroup, PartitionProducerStateChecker partitionProducerStateChecker, Executor executor, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory)IMPORTANT: This constructor may not start any work that would need to be undone in the case of a failing task deployment.
-