Uses of Interface
org.apache.flink.runtime.blob.PermanentBlobService
-
-
Uses of PermanentBlobService in org.apache.flink.runtime.blob
Subinterfaces of PermanentBlobService in org.apache.flink.runtime.blob Modifier and Type Interface Description interface
JobPermanentBlobService
PermanentBlobService
extension that gives access to register and release job artifacts.Classes in org.apache.flink.runtime.blob that implement PermanentBlobService Modifier and Type Class Description class
BlobServer
This class implements the BLOB server.class
PermanentBlobCache
Provides a cache for permanent BLOB files including a per-job ref-counting and a staged cleanup.Methods in org.apache.flink.runtime.blob that return PermanentBlobService Modifier and Type Method Description PermanentBlobService
BlobServer. getPermanentBlobService()
PermanentBlobService
BlobService. getPermanentBlobService()
Returns a BLOB service for accessing permanent BLOBs. -
Uses of PermanentBlobService in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment with parameters of type PermanentBlobService Modifier and Type Method Description void
TaskDeploymentDescriptor. loadBigData(PermanentBlobService blobService, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,JobInformation> jobInformationCache, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskInformation> taskInformationCache, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup> shuffleDescriptorsCache)
Loads externalized data from the BLOB store back to the object.void
InputGateDeploymentDescriptor. tryLoadAndDeserializeShuffleDescriptors(PermanentBlobService blobService, org.apache.flink.api.common.JobID jobId, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup> shuffleDescriptorsCache)
-
Uses of PermanentBlobService in org.apache.flink.runtime.execution.librarycache
Constructors in org.apache.flink.runtime.execution.librarycache with parameters of type PermanentBlobService Constructor Description BlobLibraryCacheManager(PermanentBlobService blobService, BlobLibraryCacheManager.ClassLoaderFactory classLoaderFactory, boolean wrapsSystemClassLoader)
-
Uses of PermanentBlobService in org.apache.flink.runtime.filecache
Constructors in org.apache.flink.runtime.filecache with parameters of type PermanentBlobService Constructor Description FileCache(String[] tempDirectories, PermanentBlobService blobService)
-
Uses of PermanentBlobService in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor with parameters of type PermanentBlobService Modifier and Type Method Description static TaskManagerServices
TaskManagerServices. fromConfiguration(TaskManagerServicesConfiguration taskManagerServicesConfiguration, PermanentBlobService permanentBlobService, org.apache.flink.metrics.MetricGroup taskManagerMetricGroup, ExecutorService ioExecutor, org.apache.flink.util.concurrent.ScheduledExecutor scheduledExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, WorkingDirectory workingDirectory)
Creates and returns the task manager services.
-