Uses of Interface
org.apache.flink.util.UserCodeClassLoader
-
-
Uses of UserCodeClassLoader in org.apache.flink.api.common.functions.util
Constructors in org.apache.flink.api.common.functions.util with parameters of type UserCodeClassLoader Constructor Description AbstractRuntimeUDFContext(JobInfo jobInfo, TaskInfo taskInfo, UserCodeClassLoader userCodeClassLoader, ExecutionConfig executionConfig, Map<String,Accumulator<?,?>> accumulators, Map<String,Future<Path>> cpTasks, OperatorMetricGroup metrics)
-
Uses of UserCodeClassLoader in org.apache.flink.api.common.serialization
Methods in org.apache.flink.api.common.serialization that return UserCodeClassLoader Modifier and Type Method Description UserCodeClassLoader
DeserializationSchema.InitializationContext. getUserCodeClassLoader()
Gets theUserCodeClassLoader
to load classes that are not in system's classpath, but are part of the jar file of a user job.UserCodeClassLoader
SerializationSchema.InitializationContext. getUserCodeClassLoader()
Gets theUserCodeClassLoader
to load classes that are not in system's classpath, but are part of the jar file of a user job. -
Uses of UserCodeClassLoader in org.apache.flink.api.connector.sink2
Methods in org.apache.flink.api.connector.sink2 that return UserCodeClassLoader Modifier and Type Method Description UserCodeClassLoader
WriterInitContext. getUserCodeClassLoader()
Gets theUserCodeClassLoader
to load classes that are not in system's classpath, but are part of the jar file of a user job. -
Uses of UserCodeClassLoader in org.apache.flink.api.connector.source
Methods in org.apache.flink.api.connector.source that return UserCodeClassLoader Modifier and Type Method Description UserCodeClassLoader
SourceReaderContext. getUserCodeClassLoader()
Gets theUserCodeClassLoader
to load classes that are not in system's classpath, but are part of the jar file of a user job. -
Uses of UserCodeClassLoader in org.apache.flink.connector.testutils.formats
Methods in org.apache.flink.connector.testutils.formats that return UserCodeClassLoader Modifier and Type Method Description UserCodeClassLoader
DummyInitializationContext. getUserCodeClassLoader()
-
Uses of UserCodeClassLoader in org.apache.flink.connector.testutils.source.deserialization
Methods in org.apache.flink.connector.testutils.source.deserialization that return UserCodeClassLoader Modifier and Type Method Description UserCodeClassLoader
TestingDeserializationContext. getUserCodeClassLoader()
-
Uses of UserCodeClassLoader in org.apache.flink.connector.testutils.source.reader
Methods in org.apache.flink.connector.testutils.source.reader that return UserCodeClassLoader Modifier and Type Method Description UserCodeClassLoader
TestingReaderContext. getUserCodeClassLoader()
-
Uses of UserCodeClassLoader in org.apache.flink.runtime.execution
Methods in org.apache.flink.runtime.execution that return UserCodeClassLoader Modifier and Type Method Description UserCodeClassLoader
Environment. getUserCodeClassLoader()
Returns the user code class loader. -
Uses of UserCodeClassLoader in org.apache.flink.runtime.execution.librarycache
Methods in org.apache.flink.runtime.execution.librarycache that return UserCodeClassLoader Modifier and Type Method Description UserCodeClassLoader
LibraryCacheManager.ClassLoaderHandle. getOrResolveClassLoader(Collection<PermanentBlobKey> requiredJarFiles, Collection<URL> requiredClasspaths)
Gets or resolves the user code class loader for the associated job. -
Uses of UserCodeClassLoader in org.apache.flink.runtime.operators
Methods in org.apache.flink.runtime.operators with parameters of type UserCodeClassLoader Modifier and Type Method Description static <T> Collector<T>
BatchTask. initOutputs(AbstractInvokable containingTask, UserCodeClassLoader cl, TaskConfig config, List<ChainedDriver<?,?>> chainedTasksTarget, List<RecordWriter<?>> eventualOutputs, ExecutionConfig executionConfig, Map<String,Accumulator<?,?>> accumulatorMap)
Creates a writer for each output. -
Uses of UserCodeClassLoader in org.apache.flink.runtime.operators.chaining
Methods in org.apache.flink.runtime.operators.chaining with parameters of type UserCodeClassLoader Modifier and Type Method Description void
ChainedDriver. setup(TaskConfig config, String taskName, Collector<OT> outputCollector, AbstractInvokable parent, UserCodeClassLoader userCodeClassLoader, ExecutionConfig executionConfig, Map<String,Accumulator<?,?>> accumulatorMap)
-
Uses of UserCodeClassLoader in org.apache.flink.runtime.operators.util
Constructors in org.apache.flink.runtime.operators.util with parameters of type UserCodeClassLoader Constructor Description DistributedRuntimeUDFContext(JobInfo jobInfo, TaskInfo taskInfo, UserCodeClassLoader userCodeClassLoader, ExecutionConfig executionConfig, Map<String,Future<Path>> cpTasks, Map<String,Accumulator<?,?>> accumulators, OperatorMetricGroup metrics, ExternalResourceInfoProvider externalResourceInfoProvider)
-
Uses of UserCodeClassLoader in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager that return UserCodeClassLoader Modifier and Type Method Description UserCodeClassLoader
RuntimeEnvironment. getUserCodeClassLoader()
Constructors in org.apache.flink.runtime.taskmanager with parameters of type UserCodeClassLoader Constructor Description RuntimeEnvironment(JobID jobId, JobType jobType, JobVertexID jobVertexId, ExecutionAttemptID executionId, ExecutionConfig executionConfig, JobInfo jobInfo, TaskInfo taskInfo, Configuration jobConfiguration, Configuration taskConfiguration, UserCodeClassLoader userCodeClassLoader, MemoryManager memManager, SharedResources sharedResources, IOManager ioManager, BroadcastVariableManager bcVarManager, TaskStateManager taskStateManager, GlobalAggregateManager aggregateManager, AccumulatorRegistry accumulatorRegistry, TaskKvStateRegistry kvStateRegistry, InputSplitProvider splitProvider, Map<String,Future<Path>> distCacheEntries, ResultPartitionWriter[] writers, IndexedInputGate[] inputGates, TaskEventDispatcher taskEventDispatcher, CheckpointResponder checkpointResponder, TaskOperatorEventGateway operatorEventGateway, TaskManagerRuntimeInfo taskManagerInfo, TaskMetricGroup metrics, Task containingTask, ExternalResourceInfoProvider externalResourceInfoProvider, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory, TaskManagerActions taskManagerActions)
-
Uses of UserCodeClassLoader in org.apache.flink.state.api.runtime
Methods in org.apache.flink.state.api.runtime that return UserCodeClassLoader Modifier and Type Method Description UserCodeClassLoader
SavepointEnvironment. getUserCodeClassLoader()
-
Uses of UserCodeClassLoader in org.apache.flink.util
Classes in org.apache.flink.util that implement UserCodeClassLoader Modifier and Type Class Description class
SimpleUserCodeClassLoader
SimpleUserCodeClassLoader
implementation which assumes that the provided class loader will never be released and, hence, will never execute the release hooks.
-