Package org.apache.flink.runtime.shuffle
Class ShuffleEnvironmentContext
- java.lang.Object
-
- org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
public class ShuffleEnvironmentContext extends Object
Local context used to createShuffleEnvironment.
-
-
Constructor Summary
Constructors Constructor Description ShuffleEnvironmentContext(org.apache.flink.configuration.Configuration configuration, ResourceID taskExecutorResourceId, org.apache.flink.configuration.MemorySize networkMemorySize, boolean localCommunicationOnly, InetAddress hostAddress, int numberOfSlots, String[] tmpDirPaths, TaskEventPublisher eventPublisher, org.apache.flink.metrics.MetricGroup parentMetricGroup, Executor ioExecutor, org.apache.flink.util.concurrent.ScheduledExecutor scheduledExecutor)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description org.apache.flink.configuration.ConfigurationgetConfiguration()TaskEventPublishergetEventPublisher()InetAddressgetHostAddress()ExecutorgetIoExecutor()org.apache.flink.configuration.MemorySizegetNetworkMemorySize()intgetNumberOfSlots()org.apache.flink.metrics.MetricGroupgetParentMetricGroup()org.apache.flink.util.concurrent.ScheduledExecutorgetScheduledExecutor()ResourceIDgetTaskExecutorResourceId()String[]getTmpDirPaths()booleanisLocalCommunicationOnly()
-
-
-
Constructor Detail
-
ShuffleEnvironmentContext
public ShuffleEnvironmentContext(org.apache.flink.configuration.Configuration configuration, ResourceID taskExecutorResourceId, org.apache.flink.configuration.MemorySize networkMemorySize, boolean localCommunicationOnly, InetAddress hostAddress, int numberOfSlots, String[] tmpDirPaths, TaskEventPublisher eventPublisher, org.apache.flink.metrics.MetricGroup parentMetricGroup, Executor ioExecutor, org.apache.flink.util.concurrent.ScheduledExecutor scheduledExecutor)
-
-
Method Detail
-
getConfiguration
public org.apache.flink.configuration.Configuration getConfiguration()
-
getTaskExecutorResourceId
public ResourceID getTaskExecutorResourceId()
-
getNetworkMemorySize
public org.apache.flink.configuration.MemorySize getNetworkMemorySize()
-
isLocalCommunicationOnly
public boolean isLocalCommunicationOnly()
-
getHostAddress
public InetAddress getHostAddress()
-
getEventPublisher
public TaskEventPublisher getEventPublisher()
-
getParentMetricGroup
public org.apache.flink.metrics.MetricGroup getParentMetricGroup()
-
getIoExecutor
public Executor getIoExecutor()
-
getScheduledExecutor
public org.apache.flink.util.concurrent.ScheduledExecutor getScheduledExecutor()
-
getNumberOfSlots
public int getNumberOfSlots()
-
getTmpDirPaths
public String[] getTmpDirPaths()
-
-