S
- The UDF type.OT
- The produced data type.public interface TaskContext<S,OT>
MapDriver
, or JoinDriver
) access to
the runtime components and configuration that they can use to fulfil their task.Driver
Modifier and Type | Method and Description |
---|---|
String |
formatLogString(String message) |
<X> org.apache.flink.api.common.typeutils.TypeComparator<X> |
getDriverComparator(int index) |
org.apache.flink.api.common.ExecutionConfig |
getExecutionConfig() |
<X> org.apache.flink.util.MutableObjectIterator<X> |
getInput(int index) |
<X> org.apache.flink.api.common.typeutils.TypeSerializerFactory<X> |
getInputSerializer(int index) |
IOManager |
getIOManager() |
MemoryManager |
getMemoryManager() |
org.apache.flink.util.Collector<OT> |
getOutputCollector() |
AbstractInvokable |
getOwningNepheleTask() |
S |
getStub() |
TaskConfig |
getTaskConfig() |
TaskManagerRuntimeInfo |
getTaskManagerInfo() |
ClassLoader |
getUserCodeClassLoader() |
TaskConfig getTaskConfig()
TaskManagerRuntimeInfo getTaskManagerInfo()
ClassLoader getUserCodeClassLoader()
MemoryManager getMemoryManager()
IOManager getIOManager()
<X> org.apache.flink.util.MutableObjectIterator<X> getInput(int index)
<X> org.apache.flink.api.common.typeutils.TypeSerializerFactory<X> getInputSerializer(int index)
<X> org.apache.flink.api.common.typeutils.TypeComparator<X> getDriverComparator(int index)
S getStub()
org.apache.flink.api.common.ExecutionConfig getExecutionConfig()
org.apache.flink.util.Collector<OT> getOutputCollector()
AbstractInvokable getOwningNepheleTask()
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.