Uses of Class
org.apache.flink.runtime.blob.PermanentBlobKey
-
-
Uses of PermanentBlobKey in org.apache.flink.runtime.blob
Methods in org.apache.flink.runtime.blob that return PermanentBlobKey Modifier and Type Method Description PermanentBlobKeyBlobServer. putPermanent(org.apache.flink.api.common.JobID jobId, byte[] value)PermanentBlobKeyBlobServer. putPermanent(org.apache.flink.api.common.JobID jobId, InputStream inputStream)PermanentBlobKeyBlobWriter. putPermanent(org.apache.flink.api.common.JobID jobId, byte[] value)Uploads the data of the given byte array for the given job to the BLOB server and makes it a permanent BLOB.PermanentBlobKeyBlobWriter. putPermanent(org.apache.flink.api.common.JobID jobId, InputStream inputStream)Uploads the data from the given input stream for the given job to the BLOB server and makes it a permanent BLOB.PermanentBlobKeyVoidBlobWriter. putPermanent(org.apache.flink.api.common.JobID jobId, byte[] value)PermanentBlobKeyVoidBlobWriter. putPermanent(org.apache.flink.api.common.JobID jobId, InputStream inputStream)PermanentBlobKeyBlobClient. uploadFile(org.apache.flink.api.common.JobID jobId, org.apache.flink.core.fs.Path file)Uploads a single file to thePermanentBlobServiceof the givenBlobServer.Methods in org.apache.flink.runtime.blob that return types with arguments of type PermanentBlobKey Modifier and Type Method Description static <T> org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<T>,PermanentBlobKey>BlobWriter. offloadWithException(org.apache.flink.util.SerializedValue<T> serializedValue, org.apache.flink.api.common.JobID jobId, BlobWriter blobWriter)static <T> org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<T>,PermanentBlobKey>BlobWriter. serializeAndTryOffload(T value, org.apache.flink.api.common.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> org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<T>,PermanentBlobKey>BlobWriter. tryOffload(org.apache.flink.util.SerializedValue<T> serializedValue, org.apache.flink.api.common.JobID jobId, BlobWriter blobWriter)static List<PermanentBlobKey>BlobClient. uploadFiles(InetSocketAddress serverAddress, org.apache.flink.configuration.Configuration clientConfig, org.apache.flink.api.common.JobID jobId, List<org.apache.flink.core.fs.Path> files)Uploads the JAR files to thePermanentBlobServiceof theBlobServerat the given address with HA as configured.Methods in org.apache.flink.runtime.blob with parameters of type PermanentBlobKey Modifier and Type Method Description booleanBlobServer. deletePermanent(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)Delete the uploaded data with the givenJobIDandPermanentBlobKey.booleanBlobWriter. deletePermanent(org.apache.flink.api.common.JobID jobId, PermanentBlobKey permanentBlobKey)Delete the uploaded data with the givenJobIDandPermanentBlobKey.booleanVoidBlobWriter. deletePermanent(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)FileBlobServer. getFile(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)Returns the path to a local copy of the file associated with the provided job ID and blob key.FilePermanentBlobCache. getFile(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)Returns the path to a local copy of the file associated with the provided job ID and blob key.FilePermanentBlobService. getFile(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)Returns the path to a local copy of the file associated with the provided job ID and blob key.byte[]PermanentBlobCache. readFile(org.apache.flink.api.common.JobID jobId, PermanentBlobKey blobKey)Returns the content of the file for the BLOB with the provided job ID the blob key.default byte[]PermanentBlobService. readFile(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)Returns the content of the file for the BLOB with the provided job ID the blob key. -
Uses of PermanentBlobKey in org.apache.flink.runtime.deployment
Fields in org.apache.flink.runtime.deployment declared as PermanentBlobKey Modifier and Type Field Description PermanentBlobKeyTaskDeploymentDescriptor.Offloaded. serializedValueKeyThe key of the offloaded value BLOB.Method parameters in org.apache.flink.runtime.deployment with type arguments of type PermanentBlobKey Modifier and Type Method Description voidTaskDeploymentDescriptor. 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.voidInputGateDeploymentDescriptor. tryLoadAndDeserializeShuffleDescriptors(PermanentBlobService blobService, org.apache.flink.api.common.JobID jobId, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup> shuffleDescriptorsCache)Constructors in org.apache.flink.runtime.deployment with parameters of type PermanentBlobKey Constructor Description Offloaded(PermanentBlobKey serializedValueKey)Constructor parameters in org.apache.flink.runtime.deployment with type arguments of type PermanentBlobKey Constructor Description TaskDeploymentDescriptorFactory(org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<JobInformation>,PermanentBlobKey> jobInformationOrBlobKey, org.apache.flink.api.common.JobID jobID, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, BlobWriter blobWriter, boolean nonFinishedHybridPartitionShouldBeUnknown, int offloadShuffleDescriptorsThreshold) -
Uses of PermanentBlobKey in org.apache.flink.runtime.execution.librarycache
Method parameters in org.apache.flink.runtime.execution.librarycache with type arguments of type PermanentBlobKey Modifier and Type Method Description org.apache.flink.util.UserCodeClassLoaderLibraryCacheManager.ClassLoaderHandle. getOrResolveClassLoader(Collection<PermanentBlobKey> requiredJarFiles, Collection<URL> requiredClasspaths)Gets or resolves the user code class loader for the associated job. -
Uses of PermanentBlobKey in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type PermanentBlobKey Modifier and Type Method Description org.apache.flink.shaded.guava32.com.google.common.collect.ImmutableCollection<PermanentBlobKey>JobInformation. getRequiredJarFileBlobKeys()org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<TaskInformation>,PermanentBlobKey>ExecutionJobVertex. getTaskInformationOrBlobKey()Method parameters in org.apache.flink.runtime.executiongraph with type arguments of type PermanentBlobKey Modifier and Type Method Description voidDefaultExecutionGraph. deleteBlobs(List<PermanentBlobKey> blobKeys)voidInternalExecutionGraphAccessor. deleteBlobs(List<PermanentBlobKey> blobKeys)Constructor parameters in org.apache.flink.runtime.executiongraph with type arguments of type PermanentBlobKey Constructor Description JobInformation(org.apache.flink.api.common.JobID jobId, JobType jobType, String jobName, org.apache.flink.util.SerializedValue<org.apache.flink.api.common.ExecutionConfig> serializedExecutionConfig, org.apache.flink.configuration.Configuration jobConfiguration, Collection<PermanentBlobKey> requiredJarFileBlobKeys, Collection<URL> requiredClasspathURLs) -
Uses of PermanentBlobKey in org.apache.flink.runtime.jobgraph
Methods in org.apache.flink.runtime.jobgraph that return types with arguments of type PermanentBlobKey Modifier and Type Method Description List<PermanentBlobKey>JobGraph. getUserJarBlobKeys()Returns a set of BLOB keys referring to the JAR files required to run this job.Methods in org.apache.flink.runtime.jobgraph with parameters of type PermanentBlobKey Modifier and Type Method Description voidJobGraph. addUserJarBlobKey(PermanentBlobKey key)Adds the BLOB referenced by the key to the JobGraph's dependencies.voidJobGraph. setUserArtifactBlobKey(String entryName, PermanentBlobKey blobKey) -
Uses of PermanentBlobKey in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return types with arguments of type PermanentBlobKey Modifier and Type Method Description GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,JobInformation>TaskManagerServices. getJobInformationCache()GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>TaskManagerServices. getShuffleDescriptorCache()GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskInformation>TaskManagerServices. getTaskInformationCache()
-