Modifier and Type | Class and Description |
---|---|
class |
BlobServer
This class implements the BLOB server.
|
class |
VoidBlobWriter
BlobWriter which does not support writing BLOBs to a store.
|
Modifier and Type | Method and Description |
---|---|
static <T> Either<SerializedValue<T>,PermanentBlobKey> |
BlobWriter.serializeAndTryOffload(T value,
JobID jobId,
BlobWriter blobWriter)
Serializes the given value and offloads it to the BlobServer if its size exceeds the minimum
offloading size of the BlobServer.
|
static <T> Either<SerializedValue<T>,PermanentBlobKey> |
BlobWriter.tryOffload(SerializedValue<T> serializedValue,
JobID jobId,
BlobWriter blobWriter) |
Modifier and Type | Method and Description |
---|---|
BlobWriter |
DefaultExecutionGraph.getBlobWriter() |
BlobWriter |
InternalExecutionGraphAccessor.getBlobWriter() |
Modifier and Type | Method and Description |
---|---|
static DefaultExecutionGraph |
DefaultExecutionGraphBuilder.buildGraph(JobGraph jobGraph,
Configuration jobManagerConfig,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
ClassLoader classLoader,
CompletedCheckpointStore completedCheckpointStore,
CheckpointsCleaner checkpointsCleaner,
CheckpointIDCounter checkpointIdCounter,
Time rpcTimeout,
MetricGroup metrics,
BlobWriter blobWriter,
org.slf4j.Logger log,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint,
ExecutionDeploymentListener executionDeploymentListener,
ExecutionStateUpdateListener executionStateUpdateListener,
long initializationTimestamp,
VertexAttemptNumberStore vertexAttemptNumberStore,
VertexParallelismStore vertexParallelismStore) |
Constructor and Description |
---|
DefaultExecutionGraph(JobInformation jobInformation,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
Time rpcTimeout,
int maxPriorAttemptsHistoryLength,
ClassLoader userClassLoader,
BlobWriter blobWriter,
PartitionGroupReleaseStrategy.Factory partitionGroupReleaseStrategyFactory,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint,
ExecutionDeploymentListener executionDeploymentListener,
ExecutionStateUpdateListener executionStateUpdateListener,
long initializationTimestamp,
VertexAttemptNumberStore initialAttemptCounts,
VertexParallelismStore vertexParallelismStore) |
Modifier and Type | Method and Description |
---|---|
BlobWriter |
JobManagerSharedServices.getBlobWriter() |
Modifier and Type | Method and Description |
---|---|
SchedulerNG |
SlotPoolServiceSchedulerFactory.createScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration configuration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener)
Creates a
SchedulerNG . |
SchedulerNG |
DefaultSlotPoolServiceSchedulerFactory.createScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration configuration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener) |
Constructor and Description |
---|
JobManagerSharedServices(ScheduledExecutorService futureExecutor,
ExecutorService ioExecutor,
LibraryCacheManager libraryCacheManager,
ShuffleMaster<?> shuffleMaster,
BlobWriter blobWriter) |
Modifier and Type | Method and Description |
---|---|
SchedulerNG |
DefaultSchedulerFactory.createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener) |
SchedulerNG |
SchedulerNGFactory.createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener) |
Constructor and Description |
---|
DefaultExecutionGraphFactory(Configuration configuration,
ClassLoader userCodeClassLoader,
ExecutionDeploymentTracker executionDeploymentTracker,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
Time rpcTimeout,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
BlobWriter blobWriter,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker jobMasterPartitionTracker) |
Modifier and Type | Method and Description |
---|---|
SchedulerNG |
AdaptiveSchedulerFactory.createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.