Constructor and Description |
---|
AbstractRuntimeUDFContext(TaskInfo taskInfo,
UserCodeClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Accumulator<?,?>> accumulators,
Map<String,Future<Path>> cpTasks,
OperatorMetricGroup metrics) |
Modifier and Type | Method and Description |
---|---|
UserCodeClassLoader |
SerializationSchema.InitializationContext.getUserCodeClassLoader()
Gets the
UserCodeClassLoader to load classes that are not in system's classpath,
but are part of the jar file of a user job. |
UserCodeClassLoader |
DeserializationSchema.InitializationContext.getUserCodeClassLoader()
Gets the
UserCodeClassLoader to load classes that are not in system's classpath,
but are part of the jar file of a user job. |
Modifier and Type | Method and Description |
---|---|
UserCodeClassLoader |
Sink.InitContext.getUserCodeClassLoader()
Gets the
UserCodeClassLoader to load classes that are not in system's classpath,
but are part of the jar file of a user job. |
UserCodeClassLoader |
InitContextInitializationContextAdapter.getUserCodeClassLoader() |
Constructor and Description |
---|
InitContextInitializationContextAdapter(UserCodeClassLoader userCodeClassLoader,
java.util.function.Supplier<MetricGroup> metricGroupSupplier) |
Modifier and Type | Method and Description |
---|---|
UserCodeClassLoader |
SourceReaderContext.getUserCodeClassLoader()
Gets the
UserCodeClassLoader to load classes that are not in system's classpath, but
are part of the jar file of a user job. |
Modifier and Type | Method and Description |
---|---|
UserCodeClassLoader |
PulsarDeserializationSchemaInitializationContext.getUserCodeClassLoader() |
Modifier and Type | Method and Description |
---|---|
UserCodeClassLoader |
TestingDeserializationContext.getUserCodeClassLoader() |
Modifier and Type | Method and Description |
---|---|
UserCodeClassLoader |
TestingReaderContext.getUserCodeClassLoader() |
Modifier and Type | Method and Description |
---|---|
UserCodeClassLoader |
Environment.getUserCodeClassLoader()
Returns the user code class loader
|
Modifier and Type | Method and Description |
---|---|
UserCodeClassLoader |
LibraryCacheManager.ClassLoaderHandle.getOrResolveClassLoader(Collection<PermanentBlobKey> requiredJarFiles,
Collection<URL> requiredClasspaths)
Gets or resolves the user code class loader for the associated job.
|
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
void |
ChainedDriver.setup(TaskConfig config,
String taskName,
Collector<OT> outputCollector,
AbstractInvokable parent,
UserCodeClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Accumulator<?,?>> accumulatorMap) |
Constructor and Description |
---|
DistributedRuntimeUDFContext(TaskInfo taskInfo,
UserCodeClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Future<Path>> cpTasks,
Map<String,Accumulator<?,?>> accumulators,
OperatorMetricGroup metrics,
ExternalResourceInfoProvider externalResourceInfoProvider,
JobID jobID) |
Modifier and Type | Method and Description |
---|---|
UserCodeClassLoader |
RuntimeEnvironment.getUserCodeClassLoader() |
Constructor and Description |
---|
RuntimeEnvironment(JobID jobId,
JobVertexID jobVertexId,
ExecutionAttemptID executionId,
ExecutionConfig executionConfig,
TaskInfo taskInfo,
Configuration jobConfiguration,
Configuration taskConfiguration,
UserCodeClassLoader userCodeClassLoader,
MemoryManager memManager,
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,
ThroughputCalculator throughputCalculator) |
Modifier and Type | Method and Description |
---|---|
UserCodeClassLoader |
SavepointEnvironment.getUserCodeClassLoader() |
Modifier and Type | Class and Description |
---|---|
class |
SimpleUserCodeClassLoader
Simple
UserCodeClassLoader implementation which assumes that the provided class loader
will never be released and, hence, will never execute the release hooks. |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.