- cache(CacheRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
-
Caches a block.
- cache(CacheRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- cache(CacheRequest, StreamObserver<CacheResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
-
- cache(CacheRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
-
- cache(CacheRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
-
- cache(CacheRequest, StreamObserver<CacheResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
-
- Cache<K,V> - Class in alluxio.master.metastore.caching
-
Base class for write-back caches which asynchronously evict entries to backing stores.
- Cache(CacheConfiguration, String, MetricKey, MetricKey, MetricKey, MetricKey, MetricKey) - Constructor for class alluxio.master.metastore.caching.Cache
-
- Cache - Class in alluxio.proto.client
-
- cache(CacheRequest) - Method in interface alluxio.worker.block.BlockWorker
-
Submits the cache request to cache manager to execute.
- Cache.Entry - Class in alluxio.master.metastore.caching
-
- Cache.PPageStoreCommonOptions - Class in alluxio.proto.client
-
Protobuf type alluxio.proto.client.PPageStoreCommonOptions
- Cache.PPageStoreCommonOptions.Builder - Class in alluxio.proto.client
-
Protobuf type alluxio.proto.client.PPageStoreCommonOptions
- Cache.PPageStoreCommonOptionsOrBuilder - Interface in alluxio.proto.client
-
- Cache.PRocksPageStoreOptions - Class in alluxio.proto.client
-
Protobuf type alluxio.proto.client.PRocksPageStoreOptions
- Cache.PRocksPageStoreOptions.Builder - Class in alluxio.proto.client
-
Protobuf type alluxio.proto.client.PRocksPageStoreOptions
- Cache.PRocksPageStoreOptionsOrBuilder - Interface in alluxio.proto.client
-
- CACHE_CLEAN_ERRORS - Static variable in class alluxio.client.file.cache.PageStore.Metrics
-
Number of failures when cleaning out the existing cache directory
to initialize a new cache.
- CACHE_PROMOTE_VALUE - Static variable in enum alluxio.grpc.ReadPType
-
CACHE_PROMOTE = 3;
- CACHE_THROUGH_VALUE - Static variable in enum alluxio.grpc.WritePType
-
CACHE_THROUGH = 3;
- CACHE_UFS_SESSION_ID - Static variable in class alluxio.Sessions
-
- CACHE_VALUE - Static variable in enum alluxio.grpc.ReadPType
-
CACHE = 2;
- CACHE_WORKER_SESSION_ID - Static variable in class alluxio.Sessions
-
- CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
-
- CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
-
- CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- CacheConfiguration - Class in alluxio.master.metastore.caching
-
Cache configuration.
- CacheConfiguration.Builder - Class in alluxio.master.metastore.caching
-
Cache configuration builder.
- CacheContext - Class in alluxio.client.file
-
Cache related context.
- CacheContext() - Constructor for class alluxio.client.file.CacheContext
-
Expected to be inherited in PrestoDB or other local cache caller.
- CacheContext.StatsUnit - Enum in alluxio.client.file
-
Stats Unit.
- CachedGroupMapping - Class in alluxio.security.group
-
Class to map user to groups.
- CachedGroupMapping(GroupMappingService, long) - Constructor for class alluxio.security.group.CachedGroupMapping
-
- cachedThreadPool(String) - Static method in class alluxio.util.executor.ExecutorServiceFactories
-
- CacheEvictor - Interface in alluxio.client.file.cache.evictor
-
Interface for client-side cache eviction policy.
- CacheEvictorOptions - Class in alluxio.client.file.cache.evictor
-
Options for initiating cache evictor.
- CacheEvictorOptions() - Constructor for class alluxio.client.file.cache.evictor.CacheEvictorOptions
-
- CacheFilter - Interface in alluxio.client.file.cache.filter
-
The Cache Filter interface which is used to determine
whether a particular file (URI) needs to be cached.
- CacheManager - Interface in alluxio.client.file.cache
-
Interface for managing cached pages.
- CacheManager.Factory - Class in alluxio.client.file.cache
-
Factory class to get or create a CacheManager.
- CacheManager.State - Enum in alluxio.client.file.cache
-
State of a cache.
- CacheManagerOptions - Class in alluxio.client.file.cache
-
Options for initiating local cache manager.
- CacheManagerOptions() - Constructor for class alluxio.client.file.cache.CacheManagerOptions
-
Constructor.
- CacheManagerWithShadowCache - Class in alluxio.client.file.cache
-
A wrapper class of CacheManager with shadow cache.
- CacheManagerWithShadowCache(CacheManager, AlluxioConfiguration) - Constructor for class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- CacheManagerWithShadowCache.PageIdFunnel - Enum in alluxio.client.file.cache
-
Funnel for PageId.
- cacheOperation(OperationId) - Method in class alluxio.master.file.meta.InodeTree
-
Used to mark an operation as complete in retry-cache.
- cacheOperation(OperationId) - Method in class alluxio.master.file.meta.InodeTreePersistentState
-
Used to mark an operation as complete in retry-cache.
- CachePerThreadContext - Class in alluxio.client.file.cache.context
-
A per-thread cache context for local cache.
- CachePerThreadContext() - Constructor for class alluxio.client.file.cache.context.CachePerThreadContext
-
- CacheQuota - Class in alluxio.client.quota
-
Data structure that stores and returns cache size in number of bytes associated with a
cache scope.
- CacheQuota(Map<CacheScope.Level, Long>) - Constructor for class alluxio.client.quota.CacheQuota
-
- CacheQuota() - Constructor for class alluxio.client.quota.CacheQuota
-
Empty cache quota.
- CacheRequest - Class in alluxio.grpc
-
Request for caching a block synchronously/asynchronously
next available id: 7
- CacheRequest.Builder - Class in alluxio.grpc
-
Request for caching a block synchronously/asynchronously
next available id: 7
- CacheRequestOrBuilder - Interface in alluxio.grpc
-
- CacheResponse - Class in alluxio.grpc
-
Response for an async cache request
- CacheResponse.Builder - Class in alluxio.grpc
-
Response for an async cache request
- CacheResponseOrBuilder - Interface in alluxio.grpc
-
- CacheScope - Class in alluxio.client.quota
-
This class defines "Scope" of a cache quota.
- CacheScope.Level - Enum in alluxio.client.quota
-
Level of a scope.
- CACHESIZE_FIELD_NUMBER - Static variable in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
- CacheStatus - Interface in alluxio.client.file.cache
-
Mixin interface for various cache status info.
- CacheUsage - Interface in alluxio.client.file.cache
-
Cache usage.
- CacheUsage.DirPartition - Class in alluxio.client.file.cache
-
Partition on a particular cache directory.
- CacheUsage.FilePartition - Class in alluxio.client.file.cache
-
Partition on a particular file.
- CacheUsage.PartitionDescriptor<T> - Interface in alluxio.client.file.cache
-
Partition descriptor.
- CacheUsage.ScopePartition - Class in alluxio.client.file.cache
-
Partition on a cache scope.
- CacheUsageView - Interface in alluxio.client.file.cache
-
Immutable view of cache usage stats.
- CacheUsageView.ImmutableCacheUsageView - Class in alluxio.client.file.cache
-
Immutable holder of cache stats.
- CachingInodeStore - Class in alluxio.master.metastore.caching
-
An inode store which caches inode tree metadata and delegates to another inode store for cache
misses.
- CachingInodeStore(InodeStore, InodeLockManager) - Constructor for class alluxio.master.metastore.caching.CachingInodeStore
-
- calculateCost(String, Map<String, Long>) - Static method in class alluxio.master.metrics.CloudCostUtils
-
Calculate the saved cost from the perUfs Operations saved map.
- calculateObjectSize(Object) - Method in class alluxio.util.ObjectSizeCalculator
-
Given an object, returns the total allocated size, in bytes, of the object
and all other objects reachable from it.
- calculatePercentiles() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
From the collected operation data, calculates 100 percentiles.
- call() - Method in interface alluxio.AbstractClient.RpcCallable
-
The task where RPC happens.
- call() - Method in class alluxio.cli.BasicCheckpoint
-
- call() - Method in class alluxio.cli.BasicNonByteBufferOperations
-
- call() - Method in class alluxio.cli.BasicOperations
-
- call(Logger, AlluxioFuseUtils.FuseCallable, String, String, Object...) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
- call() - Method in interface alluxio.fuse.AlluxioFuseUtils.FuseCallable
-
The RPC implementation.
- call() - Method in interface alluxio.membership.AlluxioEtcdClient.EtcdUtilCallable
-
The task where logics to communicate with etcd happens.
- call(NettyRPCContext, ProtoMessage) - Static method in class alluxio.network.netty.NettyRPC
-
Sends a request and waits for a response.
- call() - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
-
- call(String, S3RestUtils.RestCallable<T>) - Static method in class alluxio.proxy.s3.S3RestUtils
-
- call() - Method in interface alluxio.proxy.s3.S3RestUtils.RestCallable
-
The REST endpoint implementation.
- call(RestUtils.RestCallable<T>, AlluxioConfiguration, Map<String, Object>) - Static method in class alluxio.RestUtils
-
- call(RestUtils.RestCallable<T>, AlluxioConfiguration) - Static method in class alluxio.RestUtils
-
Call response.
- call() - Method in interface alluxio.RestUtils.RestCallable
-
The REST endpoint implementation.
- call(Logger, RpcUtils.RpcCallableThrowsIOException<T>, String, String, StreamObserver<T>, Object...) - Static method in class alluxio.RpcUtils
-
- call(Logger, RpcUtils.RpcCallableThrowsIOException<T>, String, boolean, String, StreamObserver<T>, Object...) - Static method in class alluxio.RpcUtils
-
- call() - Method in interface alluxio.RpcUtils.NettyRPCCallable
-
The RPC implementation.
- call() - Method in interface alluxio.RpcUtils.RpcCallableThrowsIOException
-
The RPC implementation.
- call() - Method in interface alluxio.RpcUtils.StreamingRpcCallable
-
The RPC implementation.
- call(String, NettyRestUtils.RestCallable<T>) - Static method in class alluxio.s3.NettyRestUtils
-
- call() - Method in interface alluxio.s3.NettyRestUtils.RestCallable
-
The REST endpoint implementation.
- callAndReturn(Logger, RpcUtils.RpcCallableThrowsIOException<T>, String, boolean, String, Object...) - Static method in class alluxio.RpcUtils
-
- CallTracker - Interface in alluxio.master.file.contexts
-
An interface for RPC level call tracking.
- CallTracker.Type - Enum in alluxio.master.file.contexts
-
Defines call-tracker types.
- cancel() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
-
- cancel() - Method in class alluxio.client.block.stream.GrpcBlockingStream
-
Cancels the stream.
- cancel() - Method in class alluxio.client.block.stream.GrpcDataWriter
-
- cancel() - Method in class alluxio.client.block.stream.NettyDataWriter
-
- cancel() - Method in interface alluxio.client.Cancelable
-
Cancels an operation.
- cancel() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
-
- cancel() - Method in class alluxio.client.file.DoraFileOutStream
-
- cancel() - Method in class alluxio.client.file.FileOutStream
-
Aborts the output stream.
- cancel() - Method in class alluxio.client.file.ufs.UfsFileOutStream
-
- cancel(long) - Method in interface alluxio.client.job.JobMasterClient
-
Cancels the given job.
- cancel(long) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- cancel(boolean) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
- cancel(boolean) - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Attempts to cancel execution of this task.
- cancel(CancelPRequest, StreamObserver<CancelPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
-
Cancels the given job.
- cancel(CancelPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
-
Cancels the given job.
- cancel(CancelPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
-
Cancels the given job.
- cancel(CancelPRequest, StreamObserver<CancelPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
-
Cancels the given job.
- CANCEL - Static variable in class alluxio.job.ServiceConstants
-
- cancel(long) - Method in class alluxio.master.job.JobMaster
-
Cancels a job.
- cancel(long) - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
-
Cancels a job.
- cancel(CancelPRequest, StreamObserver<CancelPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
-
- cancel() - Method in class alluxio.master.job.plan.PlanCoordinator
-
Cancels the current job.
- cancel(long) - Method in class alluxio.master.job.workflow.WorkflowTracker
-
Cancels a job with a particular job id.
- cancel() - Method in class alluxio.master.journal.AbstractCatchupThread
-
Cancels catching up gracefully.
- cancel() - Method in class alluxio.master.journal.CatchupFuture
-
Cancels catchup progress gracefully.
- cancel() - Method in class alluxio.worker.netty.NettyReadHandlerStateMachine
-
Cancel an ongoing read request.
- CANCEL_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
- CANCEL_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
-
- CANCEL_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
-
- Cancelable - Interface in alluxio.client
-
This interface should be implemented by all Alluxio output streams which support aborting the
temporary data that has been written.
- cancelAbort(FileSystem, FileSystem, String, String, String) - Static method in class alluxio.proxy.s3.MultipartUploadCleaner
-
Cancel schedule task.
- cancelAllPrefetch() - Method in class alluxio.underfs.UfsStatusCache
-
Interrupts and cancels any currently running prefetch jobs.
- CANCELED_VALUE - Static variable in enum alluxio.grpc.Status
-
CANCELED = 2;
- CanceledException - Exception in alluxio.exception.status
-
Exception indicating that an operation was cancelled (typically by the caller).
- CanceledException(String) - Constructor for exception alluxio.exception.status.CanceledException
-
- CanceledException(Throwable) - Constructor for exception alluxio.exception.status.CanceledException
-
- CanceledException(String, Throwable) - Constructor for exception alluxio.exception.status.CanceledException
-
- CANCELLED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
-
Canceled indicates the operation was cancelled (typically by the caller).
- CancelledException - Exception in alluxio.exception.status
-
Exception indicating that an operation was cancelled (typically by the caller).
- CancelledException(String) - Constructor for exception alluxio.exception.status.CancelledException
-
- CancelledException(Throwable) - Constructor for exception alluxio.exception.status.CancelledException
-
- CancelledException(String, Throwable) - Constructor for exception alluxio.exception.status.CancelledException
-
- CancelledResponseEvent - Class in alluxio.client.file.dora.netty.event
-
Cancelled response event.
- CancelledResponseEvent() - Constructor for class alluxio.client.file.dora.netty.event.CancelledResponseEvent
-
Cancelled response event.
- CancelledRuntimeException - Exception in alluxio.exception.runtime
-
Exception indicating that the service is cancelled or interrupted (typically by the caller).
- CancelledRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.CancelledRuntimeException
-
Constructor.
- CancelledRuntimeException(String) - Constructor for exception alluxio.exception.runtime.CancelledRuntimeException
-
Constructor.
- CancelPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CancelPOptions
- CancelPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CancelPOptions
- CancelPOptionsOrBuilder - Interface in alluxio.grpc
-
- CancelPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CancelPRequest
- CancelPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CancelPRequest
- CancelPRequestOrBuilder - Interface in alluxio.grpc
-
- CancelPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CancelPResponse
- CancelPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CancelPResponse
- CancelPResponseOrBuilder - Interface in alluxio.grpc
-
- cancelRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
-
- cancelRequest(BlockWriteRequestContext) - Method in class alluxio.worker.netty.FileWriteHandler.BlockPacketWriter
-
- cancelRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
-
- cancelTask(long, long) - Method in class alluxio.worker.job.task.TaskExecutorManager
-
Cancels the given task.
- CancelTaskCommand - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CancelTaskCommand
- CancelTaskCommand.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CancelTaskCommand
- CANCELTASKCOMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.JobCommand
-
- CancelTaskCommandOrBuilder - Interface in alluxio.grpc
-
- CANDIDATES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.EquatableValueSet
-
- canHandleShutdownHooks() - Static method in class alluxio.jnifuse.utils.SecurityUtils
-
- canonicalizeUri(URI) - Method in class alluxio.hadoop.AbstractFileSystem
-
- CANREGISTERAGAIN_FIELD_NUMBER - Static variable in class alluxio.grpc.DecommissionWorkerPOptions
-
- CanUnbuffer - Interface in alluxio.client
-
indicate that InputStream can clear their buffers on request.
- canUseReservedSpace() - Method in class alluxio.worker.block.AllocateOptions
-
- capacity() - Method in interface alluxio.client.file.cache.CacheUsageView
-
Total capacity of the cache.
- capacity() - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
-
- Capacity - Class in alluxio.wire
-
Class that represents the available, free, and total capacity.
- Capacity() - Constructor for class alluxio.wire.Capacity
-
- CAPACITY_BYTES_ON_TIERS_VALUE - Static variable in enum alluxio.grpc.BlockMasterInfoField
-
CAPACITY_BYTES_ON_TIERS = 2;
- CAPACITY_BYTES_VALUE - Static variable in enum alluxio.grpc.BlockMasterInfoField
-
CAPACITY_BYTES = 1;
- CAPACITYBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockMasterInfo
-
- CAPACITYBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
-
- CAPACITYBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPOptions
-
- CAPACITYBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockMasterInfo
-
- CAPACITYBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
-
- castToIOException(Throwable) - Static method in class alluxio.util.CommonUtils
-
- catchup(Map<String, Long>) - Method in interface alluxio.master.journal.JournalSystem
-
Initiates a catching up of journals to given sequences.
- catchup(Map<String, Long>) - Method in class alluxio.master.journal.noop.NoopJournalSystem
-
- catchup(long) - Method in class alluxio.master.journal.raft.BufferedJournalApplier
-
Initiates catching up of the applier to a target sequence.
- catchup(long) - Method in class alluxio.master.journal.raft.JournalStateMachine
-
Initiates catching up of masters to given sequence.
- catchup(Map<String, Long>) - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- catchup(long) - Method in class alluxio.master.journal.ufs.UfsJournal
-
Initiates catching up of the journal up to given sequence.
- catchup(Map<String, Long>) - Method in class alluxio.master.journal.ufs.UfsJournalSystem
-
- CatchupFuture - Class in alluxio.master.journal
-
Used to track and cancel journal advancing.
- CatchupFuture(AbstractCatchupThread) - Constructor for class alluxio.master.journal.CatchupFuture
-
Creates a tracker for given catchup thread.
- CatCommand - Class in alluxio.cli.fs.command
-
Prints the file's contents to the console.
- CatCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.CatCommand
-
- CDH_PREFIX - Static variable in class alluxio.cli.hdfs.HdfsVersionValidationTask
-
- CephfsHadoopUnderFileSystem - Class in alluxio.underfs.cephfshadoop
-
- CephfsHadoopUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystem
-
- CephfsHadoopUnderFileSystemFactory - Class in alluxio.underfs.cephfshadoop
-
- CephfsHadoopUnderFileSystemFactory() - Constructor for class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystemFactory
-
- CephFSUnderFileSystem - Class in alluxio.underfs.cephfs
-
- CephFSUnderFileSystem(AlluxioURI, CephMount, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- CephFSUnderFileSystemFactory - Class in alluxio.underfs.cephfs
-
- CephFSUnderFileSystemFactory() - Constructor for class alluxio.underfs.cephfs.CephFSUnderFileSystemFactory
-
- CephInputStream - Class in alluxio.underfs.cephfs
-
A stream for reading a file from CephFS.
- CephInputStream(CephMount, int, long) - Constructor for class alluxio.underfs.cephfs.CephInputStream
-
Create a new CephInputStream.
- CephOutputStream - Class in alluxio.underfs.cephfs
-
A stream for writing a file into CephFS.
- CephOutputStream(CephMount, int) - Constructor for class alluxio.underfs.cephfs.CephOutputStream
-
Construct the CephOutputStream.
- CephSeekableInputStream - Class in alluxio.underfs.cephfs
-
The input stream of CEPHFS as under filesystem.
- CHALLENGE_VALUE - Static variable in enum alluxio.grpc.SaslMessageType
-
CHALLENGE = 0;
- changeLocalFileGroup(String, String) - Static method in class alluxio.util.io.FileUtils
-
Changes the local file's group.
- changeLocalFilePermission(String, String) - Static method in class alluxio.util.io.FileUtils
-
Changes local file's permission.
- changeLocalFileToFullPermission(String) - Static method in class alluxio.util.io.FileUtils
-
Changes local file's permission to be "rwxrwxrwx".
- changeLocalFileUser(String, String) - Static method in class alluxio.util.io.FileUtils
-
Changes the local file's user.
- CHANNEL_TYPE - Static variable in class alluxio.util.network.NettyUtils
-
- ChannelAdapters - Class in alluxio.util.io
-
Channel adapters.
- ChannelAuthenticationScheme - Enum in alluxio.grpc
-
Protobuf enum alluxio.grpc.sasl.ChannelAuthenticationScheme
- ChannelErrorResponseEvent - Class in alluxio.client.file.dora.netty.event
-
Transport error response event.
- ChannelErrorResponseEvent(Throwable) - Constructor for class alluxio.client.file.dora.netty.event.ChannelErrorResponseEvent
-
Channel error response event.
- ChannelIdInjector - Class in alluxio.security.authentication
-
Client side interceptor that is used to augment outgoing metadata with the unique id for the
channel that the RPC is being called on.
- ChannelIdInjector(UUID) - Constructor for class alluxio.security.authentication.ChannelIdInjector
-
Creates the injector that augments the outgoing metadata with given Id.
- channelRead(ChannelHandlerContext, Object) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.AbstractReadHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.HeartbeatHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.UnsupportedMessageHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.s3.S3HttpHandler
-
- channelRead0(ChannelHandlerContext, HttpObject) - Method in class alluxio.worker.http.HttpServerHandler
-
- channelReadComplete(ChannelHandlerContext) - Method in class alluxio.worker.http.HttpServerHandler
-
- channelReadComplete(ChannelHandlerContext) - Method in class alluxio.worker.s3.S3HttpHandler
-
- CHANNELREF_FIELD_NUMBER - Static variable in class alluxio.grpc.SaslMessage
-
- channelRegistered(ChannelHandlerContext) - Method in class alluxio.worker.netty.AbstractReadHandler
-
- channelType(Class<? extends ServerChannel>) - Method in class alluxio.grpc.GrpcServerBuilder
-
Sets the netty channel type.
- ChannelType - Enum in alluxio.network
-
What type of netty channel to use.
- channelUnregistered(ChannelHandlerContext) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
-
- channelUnregistered(ChannelHandlerContext) - Method in class alluxio.worker.netty.AbstractReadHandler
-
- check() - Method in class alluxio.cli.fs.command.job.JobAttempt
-
Returns the status of the job attempt.
- check(Clients) - Method in class alluxio.master.backcompat.FsTestOp
-
- check(FileSystem) - Method in class alluxio.master.backcompat.FsTestOp
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.AsyncPersist
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.CreateDirectory
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.CreateFile
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.Delete
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.Mount
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.PersistDirectory
-
- check(Clients) - Method in class alluxio.master.backcompat.ops.PersistFile
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.Rename
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.SetAcl
-
- check(Clients) - Method in class alluxio.master.backcompat.ops.UpdateUfsMode
-
- check(Clients) - Method in interface alluxio.master.backcompat.TestOp
-
Verifies the result of the test operation.
- CHECK_CONTENT_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyJobPOptions
-
- CHECK_CONTENT_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveJobPOptions
-
- CHECK_CONTENT_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteOptions
-
- CHECK_CONTENT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
-
- CHECK_CONTENT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
-
- CHECK_FILE_EXISTS - Static variable in class alluxio.conf.PropertyKey
-
- checkAccess(AlluxioURI, CheckAccessPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
-
- checkAccess(AlluxioURI, CheckAccessPOptions) - Method in interface alluxio.client.file.FileSystem
-
Checks access to a path.
- checkAccess(AlluxioURI, CheckAccessPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Check access to a path.
- checkAccess(AlluxioURI, CheckAccessPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- checkAccess(AlluxioURI, CheckAccessPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- checkAccess(CheckAccessPRequest, StreamObserver<CheckAccessPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Checks access to path.
- checkAccess(CheckAccessPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Checks access to path.
- checkAccess(CheckAccessPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Checks access to path.
- checkAccess(CheckAccessPRequest, StreamObserver<CheckAccessPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Checks access to path.
- checkAccess(AlluxioURI, CheckAccessContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- checkAccess(AlluxioURI, CheckAccessContext) - Method in interface alluxio.master.file.FileSystemMaster
-
Checks access to path.
- checkAccess(CheckAccessPRequest, StreamObserver<CheckAccessPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- CheckAccessContext - Class in alluxio.master.file.contexts
-
- checkAccessDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- CheckAccessPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPOptions
- CheckAccessPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPOptions
- CheckAccessPOptionsOrBuilder - Interface in alluxio.grpc
-
- CheckAccessPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPRequest
- CheckAccessPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPRequest
- CheckAccessPRequestOrBuilder - Interface in alluxio.grpc
-
- CheckAccessPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPResponse
- CheckAccessPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPResponse
- CheckAccessPResponseOrBuilder - Interface in alluxio.grpc
-
- checkAndAcquireSharedLock() - Method in class alluxio.rocks.RocksStore
-
This is the core logic of the shared lock mechanism.
- CheckCachedCommand - Class in alluxio.cli.fs.command
-
Moves a file or a directory in the Alluxio filesystem using job service.
- CheckCachedCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.CheckCachedCommand
-
- CheckCluster - Class in alluxio.cli
-
In this test, we cover all workers by performing the following steps:
1.
- checkConflicts() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
-
- checkConsistency(AlluxioURI, CheckConsistencyPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Checks the consistency of Alluxio metadata against the under storage for all files and
directories in a given subtree.
- checkConsistency(AlluxioURI, CheckConsistencyPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- checkConsistency(CheckConsistencyPRequest, StreamObserver<CheckConsistencyPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Checks the consistency of the files and directores with the path as the root of the subtree
- checkConsistency(CheckConsistencyPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Checks the consistency of the files and directores with the path as the root of the subtree
- checkConsistency(CheckConsistencyPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Checks the consistency of the files and directores with the path as the root of the subtree
- checkConsistency(CheckConsistencyPRequest, StreamObserver<CheckConsistencyPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Checks the consistency of the files and directores with the path as the root of the subtree
- checkConsistency(AlluxioURI, CheckConsistencyContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- checkConsistency(AlluxioURI, CheckConsistencyContext) - Method in interface alluxio.master.file.FileSystemMaster
-
Checks the consistency of the files and directories in the subtree under the path.
- checkConsistency(CheckConsistencyPRequest, StreamObserver<CheckConsistencyPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- CheckConsistencyContext - Class in alluxio.master.file.contexts
-
- checkConsistencyDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- CheckConsistencyPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckConsistencyPOptions
- CheckConsistencyPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckConsistencyPOptions
- CheckConsistencyPOptionsOrBuilder - Interface in alluxio.grpc
-
- CheckConsistencyPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckConsistencyPRequest
- CheckConsistencyPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckConsistencyPRequest
- CheckConsistencyPRequestOrBuilder - Interface in alluxio.grpc
-
- CheckConsistencyPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckConsistencyPResponse
- CheckConsistencyPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckConsistencyPResponse
- CheckConsistencyPResponseOrBuilder - Interface in alluxio.grpc
-
- checkCopyPermission(String, String) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- checkDirectory(InodeDirectory, AlluxioURI) - Method in class alluxio.master.file.UfsSyncChecker
-
Check if immediate children of directory are in sync with UFS.
- checkExistsForPath(String) - Method in class alluxio.membership.AlluxioEtcdClient
-
Check existence of a single given path.
- checkFileLocation(String, GetStatusPOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
-
Get a map that maps file path to the workers list.
- checkFileLocation(AlluxioURI) - Method in class alluxio.client.file.DoraCacheFileSystem
-
Check the location of the specified path.
- checkFileLocation(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
-
Check the location of the specified path.
- checkIfComplete(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
-
On any exception, check with Master on if the there's an object file.
- checkIfComplete(String) - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
-
On any exception, check with Master on if the there's an object file.
- checkInodeList(String, List<String>, Mode.Bits, String, List<InodeView>, boolean) - Method in class alluxio.master.file.DefaultPermissionChecker
-
This method provides basic permission checking logic on a list of inodes.
- checkJobStatus() - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Returns the status of the job.
- checkMasterClientService(AlluxioConfiguration) - Static method in class alluxio.cli.fsadmin.FileSystemAdminShellUtils
-
Checks if the master client service is available.
- checkMinimalPollingPeriod(TimeUnit, int) - Static method in class alluxio.metrics.MetricsSystem
-
Checks if the poll period is smaller that the minimal poll period which is 1 second.
- checkMovePermission(String, String) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- checkNameLength(AlluxioURI) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Checks the input file length.
- checkNameservice() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
-
- checkNumOfArgsEquals(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
-
Checks the number of non-option arguments equals n for command.
- checkNumOfArgsNoLessThan(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
-
Checks the number of non-option arguments is no less than n for command.
- checkNumOfArgsNoMoreThan(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
-
Checks the number of non-option arguments is no more than n for command.
- checkParentPermission(Mode.Bits, LockedInodePath) - Method in class alluxio.master.file.DefaultPermissionChecker
-
- checkParentPermission(Mode.Bits, LockedInodePath) - Method in interface alluxio.master.file.PermissionChecker
-
Checks whether a user has permission to perform a specific action on the parent of the given
path; if parent directory does not exist, treats the closest ancestor directory of the path as
its parent and checks permission on it.
- checkPathIsAlluxioDirectory(FileSystem, String, S3AuditContext) - Static method in class alluxio.proxy.s3.S3RestUtils
-
Check if a path in alluxio is a directory.
- checkPathIsAlluxioDirectory(FileSystem, String, S3AuditContext, Cache<String, Boolean>) - Static method in class alluxio.proxy.s3.S3RestUtils
-
Check if a path in alluxio is a directory.
- checkPathIsAlluxioDirectory(FileSystem, String, S3AuditContext) - Static method in class alluxio.worker.s3.S3NettyHandler
-
Check if a path in alluxio is a directory.
- checkPermission(Mode.Bits, LockedInodePath) - Method in class alluxio.master.file.DefaultPermissionChecker
-
- checkPermission(String, List<String>, AclAction) - Method in class alluxio.master.file.meta.Inode
-
- checkPermission(String, List<String>, AclAction) - Method in interface alluxio.master.file.meta.InodeView
-
Checks whether the user or one of the groups has the permission to take the action.
- checkPermission(String, List<String>, AclAction) - Method in class alluxio.master.file.meta.MutableInode
-
- checkPermission(Mode.Bits, LockedInodePath) - Method in interface alluxio.master.file.PermissionChecker
-
Checks whether a user has permission to perform a specific action on a path.
- checkPermission(String, List<String>, AclAction) - Method in class alluxio.security.authorization.AccessControlList
-
Checks whether the user has the permission to perform the action.
- checkpoint() - Method in interface alluxio.client.meta.MetaMasterClient
-
Creates a checkpoint in the primary master journal system.
- checkpoint() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
-
- checkpoint(CheckpointPOptions, StreamObserver<CheckpointPResponse>) - Method in interface alluxio.grpc.MetaMasterClientServiceGrpc.AsyncService
-
Creates a checkpoint in the primary master journal system.
- checkpoint(CheckpointPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
-
Creates a checkpoint in the primary master journal system.
- checkpoint(CheckpointPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
-
Creates a checkpoint in the primary master journal system.
- checkpoint(CheckpointPOptions, StreamObserver<CheckpointPResponse>) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
-
Creates a checkpoint in the primary master journal system.
- checkpoint(StateLockManager) - Method in interface alluxio.master.journal.JournalSystem
-
Creates a checkpoint in the primary master journal system.
- checkpoint(StateLockManager) - Method in class alluxio.master.journal.noop.NoopJournalSystem
-
- checkpoint(StateLockManager) - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- checkpoint() - Method in class alluxio.master.journal.ufs.UfsJournal
-
Creates a checkpoint in this ufs journal.
- checkpoint(StateLockManager) - Method in class alluxio.master.journal.ufs.UfsJournalSystem
-
- checkpoint() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- checkpoint() - Method in interface alluxio.master.meta.MetaMaster
-
Creates a checkpoint in the primary master journal system.
- checkpoint(CheckpointPOptions, StreamObserver<CheckpointPResponse>) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
-
- CHECKPOINT - Static variable in class alluxio.multi.process.PortCoordination
-
- CheckpointCommand - Class in alluxio.cli.fsadmin.journal
-
Command for triggering a checkpoint in the primary master journal system.
- CheckpointCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.journal.CheckpointCommand
-
- Checkpointed - Interface in alluxio.master.journal.checkpoint
-
Base class for Alluxio classes which can be written to and read from metadata checkpoints.
- CheckpointedIdHashSet - Class in alluxio.master.file.meta
-
A concurrent hash set of Long values that supports writing to and restoring from checkpoints.
- CheckpointedIdHashSet() - Constructor for class alluxio.master.file.meta.CheckpointedIdHashSet
-
Constructs a new checkpointed id hash set.
- CheckpointFormat - Interface in alluxio.master.journal.checkpoint
-
Interface for checkpoint formats.
- CheckpointFormat.CheckpointReader - Interface in alluxio.master.journal.checkpoint
-
Interface for checkpoint readers.
- CheckpointInputStream - Class in alluxio.master.journal.checkpoint
-
Input stream for reading checkpoints.
- CheckpointInputStream(InputStream) - Constructor for class alluxio.master.journal.checkpoint.CheckpointInputStream
-
- CheckpointName - Enum in alluxio.master.journal.checkpoint
-
Names for associating checkpoint data with the classes they represent.
- CheckpointOutputStream - Class in alluxio.master.journal.checkpoint
-
Output stream for writing checkpoints.
- CheckpointOutputStream(OutputStream, CheckpointType) - Constructor for class alluxio.master.journal.checkpoint.CheckpointOutputStream
-
- CheckpointPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.CheckpointPOptions
- CheckpointPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.CheckpointPOptions
- CheckpointPOptionsOrBuilder - Interface in alluxio.grpc
-
- CheckpointPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.CheckpointPResponse
- CheckpointPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.CheckpointPResponse
- CheckpointPResponseOrBuilder - Interface in alluxio.grpc
-
- CheckpointType - Enum in alluxio.master.journal.checkpoint
-
Enumeration of different checkpoint types used by the master.
- checkRatio(AlluxioConfiguration, PropertyKey) - Static method in class alluxio.util.ConfigurationUtils
-
Checks that the given property key is a ratio from 0.0 and 1.0, throwing an exception if it is
not.
- CheckRequest - Class in alluxio.grpc
-
The check request
- CheckRequest.Builder - Class in alluxio.grpc
-
The check request
- CheckRequestOrBuilder - Interface in alluxio.grpc
-
- CheckResponse - Class in alluxio.grpc
-
The check response
- CheckResponse.Builder - Class in alluxio.grpc
-
The check response
- CheckResponseOrBuilder - Interface in alluxio.grpc
-
- CHECKS3BUCKETPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
-
- CHECKS3BUCKETPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
-
- checkSetAttributePermission(LockedInodePath, boolean, boolean, boolean) - Method in class alluxio.master.file.DefaultPermissionChecker
-
- checkSetAttributePermission(LockedInodePath, boolean, boolean, boolean) - Method in interface alluxio.master.file.PermissionChecker
-
Checks whether a user has permission to edit the attribute of a given path.
- checkSetTableConfig(PropertyKey, PropertyKey, PropertyKey, PropertyKey, List<RocksObject>) - Static method in class alluxio.rocks.RocksStore
-
loads RockDB configuration options based on property key configurations.
- checkStatusesForUploadId(FileSystem, FileSystem, AlluxioURI, String) - Static method in class alluxio.proxy.s3.S3RestUtils
-
Fetches and returns the corresponding
URIStatus
for both
the multipart upload temp directory and the Alluxio S3 metadata file.
- CHECKSUM_COMBINE_MODE - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- ChecksumCommand - Class in alluxio.cli.fs.command
-
Calculates the MD5 checksum for a file.
- ChecksumCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChecksumCommand
-
- ChecksumType - Enum in alluxio.underfs
-
UFS checksum type.
- checkSuperUser() - Method in class alluxio.master.file.DefaultPermissionChecker
-
- checkSuperUser() - Method in interface alluxio.master.file.PermissionChecker
-
Checks whether the user is a super user or in super group.
- checkSupported(AuthType) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
-
Used to check if given authentication is supported by the server.
- CHECKUFS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMountTablePRequest
-
- checkUnderWritableMountPoint(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
-
Checks to see if a write operation is allowed for the specified Alluxio path, by determining
if it is under a readonly mount point.
- checkVersion(long) - Method in class alluxio.AbstractClient
-
Checks that the service version is compatible with the client.
- ChgrpCommand - Class in alluxio.cli.fs.command
-
Changes the group of a file or directory specified by args.
- ChgrpCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChgrpCommand
-
- CHILD_COUNT_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
-
- CHILDREN_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
-
- chmod(String, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- chmod(String, long) - Method in class alluxio.fuse.StackFS
-
- chmod(String, long) - Method in interface alluxio.jnifuse.FuseFileSystem
-
- chmodCallback(String, long) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- ChmodCommand - Class in alluxio.cli.fs.command
-
Changes the permission of a file or directory specified by args.
- ChmodCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChmodCommand
-
- choosePreferredWorker(List<BlockWorkerInfo>) - Method in class alluxio.client.file.dora.DoraCacheClient
-
Chooses a client preferred worker from multiple workers which hold multiple replicas.
- chown(String, long, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- chown(String, long, long) - Method in class alluxio.fuse.StackFS
-
- chown(String, long, long) - Method in interface alluxio.jnifuse.FuseFileSystem
-
- chownCallback(String, long, long) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- ChownCommand - Class in alluxio.cli.fs.command
-
Changes the owner of a file or directory specified by args.
- ChownCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChownCommand
-
- Chunk - Class in alluxio.grpc
-
The data chunk.
- Chunk.Builder - Class in alluxio.grpc
-
The data chunk.
- CHUNK_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadResponse
-
- CHUNK_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotData
-
- CHUNK_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequest
-
- CHUNK_SIZE_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
-
- CHUNK_SIZE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
-
- ChunkedEncodingInputStream - Class in alluxio.s3
-
This input stream decodes an aws-chunked
encoded input stream into its original form.
- ChunkedEncodingInputStream(InputStream) - Constructor for class alluxio.s3.ChunkedEncodingInputStream
-
Creates a FilterInputStream
by assigning the argument in
to the field this.in
so as
to remember it for later use.
- ChunkOrBuilder - Interface in alluxio.grpc
-
- chunkSize() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
-
- chunkSize() - Method in interface alluxio.client.block.stream.DataWriter
-
- chunkSize() - Method in class alluxio.client.block.stream.GrpcDataWriter
-
- chunkSize() - Method in class alluxio.client.block.stream.NettyDataWriter
-
- chunkSize() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
-
- CLASS_NAME_FIELD - Static variable in interface alluxio.util.JsonSerializable
-
This must match the java field for the class name.
- classBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
-
- CLEAN_CHECK_DATA - Static variable in class alluxio.cli.fs.command.ConsistentHashCommand
-
- cleanCheckData() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
-
Clean all the check data.
- cleanDirectBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
-
Forces to unmap a direct buffer if this buffer is no longer used.
- cleanPath(String) - Static method in class alluxio.util.io.PathUtils
-
Checks and normalizes the given path.
- cleanup() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- cleanup(Collection<Long>) - Method in class alluxio.master.job.workflow.WorkflowTracker
-
Recursively cleanup the parent workflows given plans to be removed from the PlanTracker.
- cleanup() - Method in class alluxio.stress.cli.Benchmark
-
Perform post-run cleanups.
- cleanup() - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- cleanup() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- cleanup() - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- cleanup() - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- cleanup() - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- cleanup() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- cleanup() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- cleanup() - Method in interface alluxio.underfs.UnderFileSystem
-
Cleans up the under file system.
- cleanup() - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- cleanupOldSnapshots(SnapshotRetentionPolicy) - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
-
- cleanupRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
-
- cleanupRequest(BlockWriteRequestContext) - Method in class alluxio.worker.netty.FileWriteHandler.BlockPacketWriter
-
- cleanupRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
-
- cleanupSession(long) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- cleanupSession(long) - Method in interface alluxio.worker.SessionCleanable
-
Cleans up the session.
- cleanupSessionTempBlocks(long, List<Long>) - Method in interface alluxio.worker.block.meta.StorageDir
-
Cleans up the temp block metadata for each block id passed in.
- cleanupStaleJob() - Method in class alluxio.master.scheduler.Scheduler
-
Removes all finished jobs outside the retention time.
- cleanupTempPath(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
-
Cleanup the temp object file for complete multipart upload.
- cleanupTempPath(String) - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
-
Cleanup the temp object file for complete multipart upload.
- cleanupUfs() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- cleanupUfs() - Method in interface alluxio.master.file.FileSystemMaster
-
Periodically clean up the under file systems.
- clear(Path) - Static method in interface alluxio.client.file.cache.store.PageStoreDir
-
Clear the dir.
- clear(int) - Method in interface alluxio.collections.BitSet
-
Sets the bit specified by the index to false
.
- clear(int) - Method in class alluxio.collections.BuiltinBitSet
-
- clear() - Method in class alluxio.collections.ConcurrentHashSet
-
- clear() - Method in class alluxio.collections.ConcurrentIdentityHashMap
-
- clear() - Method in class alluxio.collections.DelegatingSet
-
- clear() - Method in interface alluxio.collections.FieldIndex
-
Removes all the entries in this index.
- clear() - Method in class alluxio.collections.IndexedSet
-
Removes all the entries in this set.
- clear() - Method in class alluxio.collections.NonUniqueFieldIndex
-
- clear() - Method in class alluxio.collections.UniqueFieldIndex
-
- clear() - Method in class alluxio.collections.UnmodifiableArrayList
-
- clear() - Method in class alluxio.conf.AlluxioProperties
-
Clears all existing user-specified properties.
- clear() - Method in class alluxio.grpc.ActionInfo.Builder
-
- clear() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
- clear() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
- clear() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
- clear() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- clear() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- clear() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- clear() - Method in class alluxio.grpc.BackupPOptions.Builder
-
- clear() - Method in class alluxio.grpc.BackupPRequest.Builder
-
- clear() - Method in class alluxio.grpc.BackupPStatus.Builder
-
- clear() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- clear() - Method in class alluxio.grpc.Block.Builder
-
- clear() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- clear() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- clear() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
- clear() - Method in class alluxio.grpc.BlockIdList.Builder
-
- clear() - Method in class alluxio.grpc.BlockInfo.Builder
-
- clear() - Method in class alluxio.grpc.BlockLocation.Builder
-
- clear() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- clear() - Method in class alluxio.grpc.BlockStatus.Builder
-
- clear() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
- clear() - Method in class alluxio.grpc.BuildVersion.Builder
-
- clear() - Method in class alluxio.grpc.CacheRequest.Builder
-
- clear() - Method in class alluxio.grpc.CacheResponse.Builder
-
- clear() - Method in class alluxio.grpc.CancelPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CancelPRequest.Builder
-
- clear() - Method in class alluxio.grpc.CancelPResponse.Builder
-
- clear() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- clear() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- clear() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- clear() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- clear() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- clear() - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- clear() - Method in class alluxio.grpc.CheckRequest.Builder
-
- clear() - Method in class alluxio.grpc.CheckResponse.Builder
-
- clear() - Method in class alluxio.grpc.Chunk.Builder
-
- clear() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- clear() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- clear() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- clear() - Method in class alluxio.grpc.ClientMetrics.Builder
-
- clear() - Method in class alluxio.grpc.CmdProgress.Builder
-
- clear() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
- clear() - Method in class alluxio.grpc.CmdSummary.Builder
-
- clear() - Method in class alluxio.grpc.Command.Builder
-
- clear() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
- clear() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
-
- clear() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
- clear() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
- clear() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
-
- clear() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- clear() - Method in class alluxio.grpc.ConfigProperties.Builder
-
- clear() - Method in class alluxio.grpc.ConfigProperty.Builder
-
- clear() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CopyRequest.Builder
-
- clear() - Method in class alluxio.grpc.CopyResponse.Builder
-
- clear() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
- clear() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
-
- clear() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- clear() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
- clear() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
- clear() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
- clear() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
-
- clear() - Method in class alluxio.grpc.DeletePOptions.Builder
-
- clear() - Method in class alluxio.grpc.DeletePRequest.Builder
-
- clear() - Method in class alluxio.grpc.DeletePResponse.Builder
-
- clear() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- clear() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- clear() - Method in class alluxio.grpc.ErrorInfo.Builder
-
- clear() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
- clear() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ExistsPResponse.Builder
-
- clear() - Method in class alluxio.grpc.File.Builder
-
- clear() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
- clear() - Method in class alluxio.grpc.FileFailure.Builder
-
- clear() - Method in class alluxio.grpc.FileInfo.Builder
-
- clear() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
- clear() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
- clear() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
- clear() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
- clear() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
- clear() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
- clear() - Method in class alluxio.grpc.FreePOptions.Builder
-
- clear() - Method in class alluxio.grpc.FreePRequest.Builder
-
- clear() - Method in class alluxio.grpc.FreePResponse.Builder
-
- clear() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
-
- clear() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
-
- clear() - Method in class alluxio.grpc.FsOpPId.Builder
-
- clear() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- clear() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- clear() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
Deprecated.
- clear() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
- clear() - Method in class alluxio.grpc.InconsistentProperties.Builder
-
- clear() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- clear() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
- clear() - Method in class alluxio.grpc.JobCommand.Builder
-
- clear() - Method in class alluxio.grpc.JobDescription.Builder
-
- clear() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
-
- clear() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
- clear() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
- clear() - Method in class alluxio.grpc.JobInfo.Builder
-
- clear() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
-
- clear() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
- clear() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
- clear() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
- clear() - Method in class alluxio.grpc.JobProgress.Builder
-
- clear() - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
- clear() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
- clear() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
- clear() - Method in class alluxio.grpc.JobUnused.Builder
-
- clear() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
- clear() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
- clear() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- clear() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
- clear() - Method in class alluxio.grpc.ListAllPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
- clear() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
-
- clear() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
- clear() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
-
- clear() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
- clear() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- clear() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
- clear() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
- clear() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
- clear() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
- clear() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
- clear() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
- clear() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
- clear() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
- clear() - Method in class alluxio.grpc.LoadRequest.Builder
-
- clear() - Method in class alluxio.grpc.LoadResponse.Builder
-
- clear() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
- clear() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
- clear() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
- clear() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
- clear() - Method in class alluxio.grpc.MasterInfo.Builder
-
- clear() - Method in class alluxio.grpc.MasterVersion.Builder
-
- clear() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
- clear() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
- clear() - Method in class alluxio.grpc.Metric.Builder
-
- clear() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
- clear() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
- clear() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
-
- clear() - Method in class alluxio.grpc.MetricValue.Builder
-
- clear() - Method in class alluxio.grpc.MountPointInfo.Builder
-
- clear() - Method in class alluxio.grpc.MountPOptions.Builder
-
- clear() - Method in class alluxio.grpc.MountPRequest.Builder
-
- clear() - Method in class alluxio.grpc.MountPResponse.Builder
-
- clear() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
- clear() - Method in class alluxio.grpc.MoveBlockResponse.Builder
-
- clear() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
- clear() - Method in class alluxio.grpc.MoveRequest.Builder
-
- clear() - Method in class alluxio.grpc.MoveResponse.Builder
-
- clear() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
- clear() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
-
- clear() - Method in class alluxio.grpc.NetAddress.Builder
-
- clear() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
-
- clear() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
- clear() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
-
- clear() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
- clear() - Method in class alluxio.grpc.PAcl.Builder
-
- clear() - Method in class alluxio.grpc.PAclEntry.Builder
-
- clear() - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
- clear() - Method in class alluxio.grpc.PersistFile.Builder
-
- clear() - Method in class alluxio.grpc.PMode.Builder
-
- clear() - Method in class alluxio.grpc.PolicyInfo.Builder
-
- clear() - Method in class alluxio.grpc.PolicyStatus.Builder
-
- clear() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
- clear() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
-
- clear() - Method in class alluxio.grpc.ProxyStatus.Builder
-
- clear() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
- clear() - Method in class alluxio.grpc.ReadRequest.Builder
-
- clear() - Method in class alluxio.grpc.ReadResponse.Builder
-
- clear() - Method in class alluxio.grpc.RegisterCommand.Builder
-
- clear() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
- clear() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
- clear() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
-
- clear() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
-
- clear() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
- clear() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
- clear() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
- clear() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
- clear() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
-
- clear() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
- clear() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- clear() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
-
- clear() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
- clear() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
-
- clear() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
- clear() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
-
- clear() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
-
- clear() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
- clear() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
-
- clear() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
-
- clear() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
- clear() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
-
- clear() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
-
- clear() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
- clear() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
-
- clear() - Method in class alluxio.grpc.RenamePOptions.Builder
-
- clear() - Method in class alluxio.grpc.RenamePRequest.Builder
-
- clear() - Method in class alluxio.grpc.RenamePResponse.Builder
-
- clear() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
-
- clear() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- clear() - Method in class alluxio.grpc.RetryInfo.Builder
-
- clear() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
- clear() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
- clear() - Method in class alluxio.grpc.Route.Builder
-
- clear() - Method in class alluxio.grpc.RouteFailure.Builder
-
- clear() - Method in class alluxio.grpc.RunPOptions.Builder
-
- clear() - Method in class alluxio.grpc.RunPRequest.Builder
-
- clear() - Method in class alluxio.grpc.RunPResponse.Builder
-
- clear() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
- clear() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
- clear() - Method in class alluxio.grpc.SaslMessage.Builder
-
- clear() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
- clear() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
- clear() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
-
- clear() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
- clear() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
- clear() - Method in class alluxio.grpc.SetAclPResponse.Builder
-
- clear() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- clear() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
- clear() - Method in class alluxio.grpc.SetAttributePResponse.Builder
-
- clear() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
-
- clear() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- clear() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
-
- clear() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
- clear() - Method in class alluxio.grpc.SnapshotData.Builder
-
- clear() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
- clear() - Method in class alluxio.grpc.StatusSummary.Builder
-
- clear() - Method in class alluxio.grpc.StopJobPRequest.Builder
-
- clear() - Method in class alluxio.grpc.StopJobPResponse.Builder
-
- clear() - Method in class alluxio.grpc.StorageList.Builder
-
- clear() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
- clear() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
- clear() - Method in class alluxio.grpc.SubmitOptions.Builder
-
- clear() - Method in class alluxio.grpc.SubmitRequest.Builder
-
- clear() - Method in class alluxio.grpc.SubmitResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
- clear() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
- clear() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
- clear() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- clear() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
- clear() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
- clear() - Method in class alluxio.grpc.table.Constraint.Builder
-
- clear() - Method in class alluxio.grpc.table.Database.Builder
-
- clear() - Method in class alluxio.grpc.table.Date.Builder
-
- clear() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
- clear() - Method in class alluxio.grpc.table.Decimal.Builder
-
- clear() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
- clear() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.Domain.Builder
-
- clear() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
- clear() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
- clear() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
- clear() - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- clear() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.Layout.Builder
-
- clear() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
- clear() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- clear() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
- clear() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- clear() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- clear() - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
- clear() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
- clear() - Method in class alluxio.grpc.table.Partition.Builder
-
- clear() - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
- clear() - Method in class alluxio.grpc.table.Range.Builder
-
- clear() - Method in class alluxio.grpc.table.RangeSet.Builder
-
- clear() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.Schema.Builder
-
- clear() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
- clear() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- clear() - Method in class alluxio.grpc.table.TableInfo.Builder
-
- clear() - Method in class alluxio.grpc.table.Transformation.Builder
-
- clear() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
- clear() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
- clear() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
- clear() - Method in class alluxio.grpc.table.Value.Builder
-
- clear() - Method in class alluxio.grpc.TierList.Builder
-
- clear() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
- clear() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
-
- clear() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- clear() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- clear() - Method in class alluxio.grpc.TransportMessage.Builder
-
- clear() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
- clear() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
-
- clear() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
- clear() - Method in class alluxio.grpc.UfsInfo.Builder
-
- clear() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
- clear() - Method in class alluxio.grpc.UfsStatus.Builder
-
- clear() - Method in class alluxio.grpc.UnmountPOptions.Builder
-
- clear() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
- clear() - Method in class alluxio.grpc.UnmountPResponse.Builder
-
- clear() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- clear() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- clear() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- clear() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- clear() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- clear() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- clear() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- clear() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- clear() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- clear() - Method in class alluxio.grpc.WorkerIdentity.Builder
-
- clear() - Method in class alluxio.grpc.WorkerInfo.Builder
-
- clear() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- clear() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
- clear() - Method in class alluxio.grpc.WriteOptions.Builder
-
- clear() - Method in class alluxio.grpc.WriteRequest.Builder
-
- clear() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
- clear() - Method in class alluxio.grpc.WriteResponse.Builder
-
- clear() - Method in class alluxio.master.file.FileSystemJournalEntryMerger
-
- clear() - Method in interface alluxio.master.journal.JournalEntryMerger
-
Clears the existing journal entries.
- clear() - Method in interface alluxio.master.metastore.BlockMetaStore
-
Removes all metadata from the block store.
- clear() - Method in class alluxio.master.metastore.caching.Cache
-
Clears all entries from the map.
- clear() - Method in class alluxio.master.metastore.caching.CachingInodeStore
-
- clear() - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
-
- clear() - Method in class alluxio.master.metastore.heap.HeapInodeStore
-
- clear() - Method in interface alluxio.master.metastore.InodeStore
-
Removes all inodes and edges.
- clear() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
-
- clear() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- clear() - Method in class alluxio.master.metrics.MetricsStore
-
Clears all the metrics.
- clear() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
- clear() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
- clear() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
- clear() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
- clear() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
- clear() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
- clear() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
- clear() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
- clear() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
- clear() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
- clear() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- clear() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
- clear() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
- clear() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
- clear() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
- clear() - Method in class alluxio.rocks.RocksStore
-
Clears and re-initializes the database.
- clear() - Method in class alluxio.s3.TaggingData
-
Removes all tags contained in this object.
- clear() - Method in interface alluxio.worker.dora.DoraMetaStore
-
Removes all metadata from the dora meta store.
- clear() - Method in class alluxio.worker.dora.RocksDBDoraMetaStore
-
Clears all the metadata in this RocksDB.
- clearAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- clearAccessMode() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.Bits accessMode = 3;
- clearAcl() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl acl = 27;
- clearAcl() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- clearAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- clearAcl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- clearAcl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- clearAction() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the set action to perform
- clearAction() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional .alluxio.proto.journal.PSetAclAction action = 3;
- clearActionId() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionId = 1;
- clearActionId() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string actionId = 2;
- clearActions() - Method in class alluxio.grpc.PAclEntry.Builder
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- clearActions() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- clearActions() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- clearActions() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional .alluxio.proto.shared.AclActions actions = 2;
- clearActionsCanceled() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsCanceled = 8;
- clearActionsFailed() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsFailed = 9;
- clearActionsRunning() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsRunning = 6;
- clearActionsScheduled() - Method in class alluxio.grpc.PolicyStatus.Builder
-
metrics
- clearActionsSucceeded() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsSucceeded = 7;
- clearActionStatus() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionStatus = 3;
- clearActionType() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionType = 2;
- clearActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
action fields.
- clearAddedBlocks() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- clearAddedBlocksOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- clearAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- clearAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- clearAddress() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.NetAddress address = 1;
- clearAddress() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- clearAddress() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- clearAddresses() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
addresses are only valid when workerRange is SPECIFIED
- clearAddresses() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional .alluxio.grpc.NetAddress addresses = 1;
- clearAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- clearAffectedPaths() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- clearAll() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
optional bool all = 1;
- clearAllMetrics() - Static method in class alluxio.metrics.MetricsSystem
-
Resets the metric registry and removes all the metrics.
- clearAllOrNone() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- clearAllowed() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional bool allowed = 2;
- clearAllowedOnStandbyMasters() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
optional bool allowedOnStandbyMasters = 2;
- clearAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool allowExists = 2;
- clearAllowLeader() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool allowLeader = 3;
- clearAllThroughput() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
Clears all data points from the result.
- clearAlluxioOnly() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool alluxioOnly = 2;
- clearAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
Deprecated, this field is about whether to delete in the UFS.
- clearAlluxioPath() - Method in class alluxio.grpc.File.Builder
-
optional string alluxio_path = 1;
- clearAlluxioPath() - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of alluxio mount point
- clearAlluxioPath() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
optional string alluxioPath = 1;
- clearAlluxioPath() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
the path of the alluxio mount point
- clearAlluxioPath() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
the path of alluxio mount point
- clearAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string alluxio_path = 1;
- clearAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
optional string alluxio_path = 1;
- clearAlluxioVersion() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional string alluxioVersion = 3;
- clearAsync() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional bool async = 6;
- clearAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- clearAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- clearAuthenticationScheme() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
- clearAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional double avg_col_len = 2;
- clearAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional double avg_col_len = 2;
- clearBackupError() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional bytes backupError = 6;
- clearBackupHost() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupHost = 3;
- clearBackupId() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupId = 1;
- clearBackupId() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
optional string backupId = 1;
- clearBackupState() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional .alluxio.grpc.meta.BackupState backupState = 2;
- clearBackupUri() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupUri = 4;
- clearBandwidth() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional int64 bandwidth = 1;
- clearBandwidth() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional int64 bandwidth = 1;
- clearBandwidth() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional int64 bandwidth = 1;
- clearBandwidth() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
optional int64 bandwidth = 3;
- clearBandwidth() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional int64 bandwidth = 4;
- clearBandwidth() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional int64 bandwidth = 3;
- clearBandwidth() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional int64 bandwidth = 4;
- clearBaseLayout() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- clearBatchSize() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Batch size for partial listings.
- clearBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- clearBits() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.Bits bits = 1;
- clearBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional string bit_vectors = 4;
- clearBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional string bit_vectors = 4;
- clearBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional string bit_vectors = 5;
- clearBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional string bit_vectors = 5;
- clearBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional string bit_vectors = 5;
- clearBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional string bit_vectors = 5;
- clearBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional string bit_vectors = 5;
- clearBlock() - Method in class alluxio.grpc.BlockStatus.Builder
-
required .alluxio.grpc.block.Block block = 1;
- clearBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- clearBlockCount() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
- clearBlockId() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.grpc.Block.Builder
-
required int64 block_id = 1;
- clearBlockId() - Method in class alluxio.grpc.BlockIdList.Builder
-
repeated int64 blockId = 1;
- clearBlockId() - Method in class alluxio.grpc.BlockInfo.Builder
-
optional int64 blockId = 1;
- clearBlockId() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the id of the block being committed
- clearBlockId() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
the id of the block
- clearBlockId() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional int64 block_id = 1;
- clearBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
optional int64 block_id = 1;
- clearBlockIds() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated int64 blockIds = 13;
- clearBlockIds() - Method in class alluxio.grpc.PersistFile.Builder
-
repeated int64 blockIds = 2;
- clearBlockIds() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
repeated int64 block_ids = 1;
- clearBlockInfo() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- clearBlockInfo() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- clearBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- clearBlockLocation() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- clearBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- clearBlocks() - Method in class alluxio.grpc.LoadRequest.Builder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- clearBlocks() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated int64 blocks = 12;
- clearBlocks() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated int64 blocks = 16;
- clearBlockSize() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional int64 block_size = 3;
- clearBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The block size.
- clearBlockSizeBytes() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int64 blockSizeBytes = 1;
- clearBlockSizeBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 blockSizeBytes = 6;
- clearBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 block_size_bytes = 8;
- clearBlockSizeBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 block_size_bytes = 2;
- clearBlockSizeBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
file only
- clearBlockStatus() - Method in class alluxio.grpc.LoadResponse.Builder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- clearBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- clearBooleanType() - Method in class alluxio.grpc.table.Value.Builder
-
bool boolean_type = 4;
- clearBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
optional int64 bucket_count = 2;
- clearBucketedBy() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated string bucketed_by = 1;
- clearBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- clearBuildVersion() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
the worker version to display in info pages (useful for rolling upgrades)
- clearBuildVersion() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- clearBypassDelegation() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool bypassDelegation = 4;
- clearBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
optional int64 bytes = 1;
- clearBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
optional int64 bytes = 1;
- clearBytesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
optional int64 bytes_skipped = 4;
- clearCacheable() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool cacheable = 11;
- clearCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool cacheable = 11;
- clearCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional bool cacheable = 5;
- clearCacheSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional int64 cacheSize = 2;
- clearCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
optional bool cancel = 2;
- clearCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
If set, this request is to cancel the reading request for the id.
- clearCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional bool cancel = 6;
- clearCancelTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- clearCandidates() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- clearCanRegisterAgain() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
optional bool canRegisterAgain = 3;
- clearCapacityBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 capacityBytes = 1;
- clearCapacityBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 capacityBytes = 5;
- clearCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- clearCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- clearCapacityBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
-
- clearChannelRef() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string channelRef = 5;
- clearCheckContent() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool check_content = 6;
- clearCheckContent() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool check_content = 6;
- clearCheckContent() - Method in class alluxio.grpc.WriteOptions.Builder
-
optional bool check_content = 3;
- clearCheckContent() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional bool check_content = 11;
- clearCheckContent() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional bool check_content = 11;
- clearCheckS3BucketPath() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool checkS3BucketPath = 8;
- clearCheckS3BucketPath() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool checkS3BucketPath = 14;
- clearCheckUfs() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
optional bool checkUfs = 1;
- clearChildCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 child_count = 26;
- clearChildren() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- clearChunk() - Method in class alluxio.grpc.ReadResponse.Builder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- clearChunk() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional bytes chunk = 3;
- clearChunk() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- clearChunkSize() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 chunk_size = 5;
- clearChunkSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
If set, the server should send packets in the specified packet size.
- clearClientId() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string clientId = 3;
- clearClientMetrics() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- clearClients() - Method in class alluxio.master.LocalAlluxioMaster
-
Clears all the clients.
- clearClusterConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string clusterConfigHash = 1;
- clearClusterConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string clusterConfigHash = 3;
- clearClusterConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional int64 clusterConfigLastUpdateTime = 5;
- clearClusterConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- clearClusterId() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string clusterId = 11;
- clearClusterId() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
optional string cluster_id = 1;
- clearClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- clearCmdConfig() - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional bytes cmdConfig = 1;
- clearCmdProgress() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- clearCmdStatus() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
optional .alluxio.grpc.job.Status cmdStatus = 1;
- clearCmdStatusBlock() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- clearCode() - Method in class alluxio.grpc.BlockStatus.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- clearCode() - Method in class alluxio.grpc.FileFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- clearCode() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- clearCode() - Method in class alluxio.grpc.RouteFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- clearColName() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_name = 1;
- clearColNames() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- clearColNames() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- clearCols() - Method in class alluxio.grpc.table.Schema.Builder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- clearColType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_type = 2;
- clearColumn() - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- clearColumnConstraints() - Method in class alluxio.grpc.table.Constraint.Builder
-
- clearColumnName() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
required string column_name = 1;
- ClearCommand - Class in alluxio.cli.fsadmin.metrics
-
Clear the leading master (and workers) metrics.
- ClearCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.metrics.ClearCommand
-
- clearCommand() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
optional .alluxio.grpc.Command command = 1;
- clearCommand() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- clearCommand() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
- clearCommand() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
optional .alluxio.grpc.meta.MetaCommand command = 1;
- clearCommand() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- clearCommandOptions() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- clearCommands() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- clearCommandType() - Method in class alluxio.grpc.Command.Builder
-
optional .alluxio.grpc.CommandType commandType = 1;
- clearCommandType() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.CommandType commandType = 1;
- clearComment() - Method in class alluxio.grpc.table.Database.Builder
-
optional string comment = 7;
- clearComment() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string comment = 4;
- clearCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- clearCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- clearCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- clearCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- clearCommonOptions() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- clearCommonOptions() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- clearCommonOptions() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- clearCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- clearCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- clearCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- clearCommonOptions() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- clearCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- clearCommonOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- clearCommonOptions() - Method in class alluxio.grpc.UnmountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- clearCompleted() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool completed = 8;
- clearCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool completed = 10;
- clearCompleted() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional bool completed = 4;
- clearCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- clearConfigs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- clearConfigs() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- clearConstraint() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- clearContainerHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string containerHost = 7;
- clearContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
optional int64 container_id = 1;
- clearContentHash() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional string contentHash = 4;
- clearContentHash() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string contentHash = 34;
- clearContentHash() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional string content_hash = 1;
- clearContentHash() - Method in class alluxio.grpc.WriteResponse.Builder
-
Errors will be handled by standard gRPC stream APIs.
- clearContentLength() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional int64 content_length = 2;
- clearCopyJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- clearCount() - Method in class alluxio.grpc.StatusSummary.Builder
-
optional int64 count = 2;
- clearCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional bool createAncestors = 2;
- clearCreatedAt() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional int64 created_at = 3;
- clearCreatedAt() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional int64 created_at = 3;
- clearCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- clearCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for ufs writes.
- clearCreationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 creationTimeMs = 7;
- clearCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 creation_time_ms = 6;
- clearCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 creation_time_ms = 6;
- clearCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 creation_time_ms = 6;
- clearCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 creation_time_ms = 2;
- clearCurrentBlocks() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- clearCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- clearData() - Method in class alluxio.grpc.Chunk.Builder
-
optional bytes data = 1;
- clearData() - Method in class alluxio.grpc.Command.Builder
-
repeated int64 data = 2;
- clearData() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- clearData() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- clearData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- clearData() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- clearDatabase() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
repeated string database = 1;
- clearDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
optional string database = 1;
- clearDataCols() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- clearDataPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 dataPort = 3;
- clearDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- clearDaysSinceEpoch() - Method in class alluxio.grpc.table.Date.Builder
-
required int64 days_since_epoch = 1;
- clearDb() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
optional .alluxio.grpc.table.Database db = 1;
- clearDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string db_name = 4;
- clearDbName() - Method in class alluxio.grpc.table.Database.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string db_name = 3;
- clearDbName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string db_name = 1;
- clearDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- clearDecommissionedWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 decommissionedWorkerNum = 8;
- clearDefaultAcl() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- clearDefaultAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- clearDefaultAcl() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- clearDefaultAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- clearDefinition() - Method in class alluxio.grpc.table.Transformation.Builder
-
optional string definition = 2;
- clearDefinition() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string definition = 3;
- clearDefinition() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string definition = 3;
- clearDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- clearDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- clearDeleteMountPoint() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool deleteMountPoint = 6;
- clearDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- clearDescription() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string description = 13;
- clearDescription() - Method in class alluxio.grpc.table.Database.Builder
-
optional string description = 2;
- clearDirectChildrenLoaded() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool directChildrenLoaded = 13;
- clearDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool direct_children_loaded = 12;
- clearDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional bool direct_children_loaded = 3;
- clearDisableAreDescendantsLoadedCheck() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
Setting this to true will disable checking during metadata sync to see if the children
of a directory has been loaded.
- clearDomain() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
optional .alluxio.grpc.journal.JournalDomain domain = 1;
- clearDomainSocketPath() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string domainSocketPath = 5;
- clearDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- clearDoubleType() - Method in class alluxio.grpc.table.Value.Builder
-
double double_type = 2;
- clearDoubleValue() - Method in class alluxio.grpc.MetricValue.Builder
-
optional double doubleValue = 1;
- clearDst() - Method in class alluxio.grpc.Route.Builder
-
required string dst = 2;
- clearDst() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string dst = 2;
- clearDst() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string dst = 2;
- clearDstPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string dstPath = 3;
- clearDstPath() - Method in class alluxio.grpc.RenamePRequest.Builder
-
the destination path
- clearDstPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
Deprecated, use new_parent_id/new_name instead
- clearDuration() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 duration = 6;
- clearEndTime() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional int64 end_time = 9;
- clearEndTime() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional int64 end_time = 8;
- clearEndTime() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional int64 end_time = 9;
- clearEntries() - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- clearEntries() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- clearEntries() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- clearEntries() - Method in class alluxio.security.authorization.AccessControlList
-
Clears out all entries (does not modify the owner name and owning group).
- clearEntryCount() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional int64 entryCount = 5;
- clearEof() - Method in class alluxio.grpc.SnapshotData.Builder
-
Deprecated.
- clearEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional bool eof = 5;
- clearEquatable() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- clearErrorMessage() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorMessage = 7;
- clearErrorMessage() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional string errorMessage = 7;
- clearErrorMessage() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorMessage = 2;
- clearErrorMsg() - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorMsg = 5;
- clearErrors() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- clearErrors() - Method in class alluxio.grpc.PolicyStatus.Builder
-
- clearErrorType() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorType = 6;
- clearErrorType() - Method in class alluxio.grpc.ErrorInfo.Builder
-
optional .alluxio.grpc.ErrorType errorType = 1;
- clearErrorType() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorType = 15;
- clearErrorType() - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorType = 6;
- clearExcludeMountInfo() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
Mount info will be excluded from the list status response if this field is set to true.
- clearExists() - Method in class alluxio.grpc.ExistsPResponse.Builder
-
optional bool exists = 1;
- clearExists() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional bool exists = 3;
- clearExpiryMs() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional int64 expiryMs = 3;
- clearFailures() - Method in class alluxio.grpc.CopyResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- clearFailures() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- clearFailures() - Method in class alluxio.grpc.MoveResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ActionInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupPStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Block.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockIdList.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockLocation.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BuildVersion.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CacheRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CacheResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Chunk.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClientMetrics.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CmdProgress.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CmdSummary.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Command.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ConfigProperties.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ConfigProperty.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CopyRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CopyResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DeletePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DeletePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DeletePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ErrorInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ExistsPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ExistsPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ExistsPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.File.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileFailure.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemCommand.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FreePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FreePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FreePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FsOpPId.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
Deprecated.
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.InconsistentProperties.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobCommand.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobDescription.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobProgress.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobUnused.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListAllPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MasterInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MasterVersion.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Metric.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MetricValue.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MountPointInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MountPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MountPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MountPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MoveBlockResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MoveRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MoveResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NetAddress.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PAcl.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PAclEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PersistFile.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PMode.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PolicyInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PolicyStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ProxyStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ReadRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ReadResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterCommand.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RenamePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RenamePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RenamePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RetryInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Route.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RouteFailure.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RunPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RunPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RunPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RunTaskCommand.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SaslMessage.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAclPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAclPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAttributePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SnapshotData.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StatusSummary.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StopJobPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StopJobPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StorageList.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SubmitOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SubmitRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SubmitResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Constraint.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Database.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Date.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Decimal.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Domain.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Layout.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Partition.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Range.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.RangeSet.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Schema.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.TableInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Transformation.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Value.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TierList.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransportMessage.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UfsFileStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UfsInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UfsStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UnmountPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UnmountPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UnmountPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WorkerIdentity.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WorkerInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WriteOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WriteRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WriteResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
- clearFieldRanges() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- clearFile() - Method in class alluxio.grpc.FileFailure.Builder
-
required .alluxio.grpc.block.File file = 1;
- clearFileBlockInfos() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- clearFileCount() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 fileCount = 2;
- clearFileCount() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
The total number of files in the listing directory,
(i.e.
- clearFileDatePattern() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string file_date_pattern = 6;
- clearFileId() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 fileId = 1;
- clearFileId() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
the id of the file
- clearFileId() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
optional int64 fileId = 1;
- clearFileId() - Method in class alluxio.grpc.PersistFile.Builder
-
optional int64 fileId = 1;
- clearFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
optional int64 file_id = 1;
- clearFileInfo() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- clearFileInfo() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- clearFileInfo() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- clearFileInfo() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- clearFileInfos() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- clearFileInfos() - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- clearFilePath() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string filePath = 4;
- clearFilePath() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string filePath = 3;
- clearFilePath() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePath = 3;
- clearFilePathFailed() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePathFailed = 4;
- clearFileSize() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 fileSize = 3;
- clearFilesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
optional int32 files_skipped = 3;
- clearFilter() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string filter = 5;
- clearFilter() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- clearFilter() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- clearFilter() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- clearFilters() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- clearFlush() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional bool flush = 5;
- clearFolder() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool folder = 9;
- clearForced() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional bool forced = 2;
- clearFormat() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
- clearFormat() - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
- clearFreeBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 freeBytes = 3;
- clearGroup() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string group = 17;
- clearGroup() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string group = 4;
- clearGroup() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string group = 5;
- clearGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string group = 3;
- clearGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string group = 9;
- clearGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string group = 15;
- clearGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string group = 7;
- clearGroup() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string group = 10;
- clearGroupActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- clearGroupBits() - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits groupBits = 2;
- clearHasDirectChildrenLoaded() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool has_direct_children_loaded = 13;
- clearHigh() - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value high = 2;
- clearHighValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date high_value = 2;
- clearHighValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- clearHighValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional double high_value = 2;
- clearHighValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 high_value = 2;
- clearHost() - Method in class alluxio.grpc.NetAddress.Builder
-
optional string host = 1;
- clearHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string host = 1;
- clearHostname() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional string hostname = 4;
- clearId() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional uint32 id = 1;
- clearId() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
The block ID or UFS file ID.
- clearId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
The block ID or UFS file ID.
- clearId() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 id = 2;
- clearId() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional int64 id = 1;
- clearId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 id = 1;
- clearIdentifier() - Method in class alluxio.grpc.WorkerIdentity.Builder
-
exactly how this byte sequence is interpreted depends on the version of its definition
- clearIgnoreClusterConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool ignoreClusterConf = 2;
- clearIgnorePathConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool ignorePathConf = 3;
- clearIgnoreSyncErrors() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional bool ignore_sync_errors = 6;
- clearInAlluxioPercentage() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 inAlluxioPercentage = 24;
- clearIncludeRealContentHash() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional bool includeRealContentHash = 5;
- clearInconsistentPaths() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
repeated string inconsistentPaths = 1;
- clearInfo() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- clearInfos() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- clearInMemoryPercentage() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 inMemoryPercentage = 25;
- clearInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- clearInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- clearInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- clearInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- clearInputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string input_format = 2;
- clearInstance() - Method in class alluxio.grpc.Metric.Builder
-
optional string instance = 1;
- clearIsAtomicWrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool isAtomicWrite = 16;
- clearIsCacheable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_cacheable = 17;
- clearIsCompleted() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_completed = 18;
- clearIsDefault() - Method in class alluxio.grpc.PAcl.Builder
-
optional bool isDefault = 5;
- clearIsDefault() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional bool isDefault = 4;
- clearIsDefault() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional bool isDefault = 7;
- clearIsDefault() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional bool isDefault = 4;
- clearIsDefaultEmpty() - Method in class alluxio.grpc.PAcl.Builder
-
optional bool isDefaultEmpty = 6;
- clearIsDirectory() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional bool is_directory = 2;
- clearIsDirectory() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_directory = 3;
- clearIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional bool isEmpty = 8;
- clearIsLeader() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional bool isLeader = 3;
- clearIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
directory only
- clearIsMultipartUpload() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
optional bool isMultipartUpload = 2;
- clearIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_pinned = 9;
- clearIsRetryable() - Method in class alluxio.grpc.RetryInfo.Builder
-
optional bool isRetryable = 1;
- clearIsScanning() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional bool isScanning = 11;
- clearIsSkip() - Method in class alluxio.grpc.RouteFailure.Builder
-
optional bool is_skip = 5;
- clearIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
optional bool isThrowable = 2;
- clearIsTruncated() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
True if the partial listing was truncated.
- clearJobConfig() - Method in class alluxio.grpc.RunPRequest.Builder
-
optional bytes jobConfig = 1;
- clearJobConfig() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional bytes jobConfig = 3;
- clearJobControlId() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
optional int64 jobControlId = 1;
- clearJobControlId() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 jobControlId = 1;
- clearJobControlId() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional int64 jobControlId = 1;
- clearJobControlId() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional int64 jobControlId = 1;
- clearJobControlId() - Method in class alluxio.grpc.SubmitResponse.Builder
-
optional int64 jobControlId = 1;
- clearJobDescription() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- clearJobDescription() - Method in class alluxio.grpc.StopJobPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- clearJobError() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string job_error = 6;
- clearJobId() - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional int64 jobId = 1;
- clearJobId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
optional int64 jobId = 1;
- clearJobId() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional int64 jobId = 1;
- clearJobId() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional int64 jobId = 1;
- clearJobId() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 jobId = 1;
- clearJobId() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional int64 jobId = 1;
- clearJobId() - Method in class alluxio.grpc.RunPResponse.Builder
-
optional int64 jobId = 1;
- clearJobId() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional int64 jobId = 1;
- clearJobId() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
optional string jobId = 1;
- clearJobId() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
optional int64 job_id = 1;
- clearJobId() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional int64 job_id = 4;
- clearJobId() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
optional int64 job_id = 1;
- clearJobId() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string job_id = 8;
- clearJobId() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string job_id = 7;
- clearJobId() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string job_id = 8;
- clearJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional bool jobIdOnly = 3;
- clearJobIds() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated int64 jobIds = 1;
- clearJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- clearJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- clearJobInfos() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- clearJobMasterId() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional int64 jobMasterId = 1;
- clearJobMasterStatus() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- clearJobProgress() - Method in class alluxio.grpc.CmdProgress.Builder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- clearJobSource() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.JobSource jobSource = 3;
- clearJobStatus() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional .alluxio.grpc.job.Status jobStatus = 2;
- clearJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional .alluxio.grpc.job.Status job_status = 5;
- clearJobStatusBlock() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- clearJobStopped() - Method in class alluxio.grpc.StopJobPResponse.Builder
-
optional bool jobStopped = 1;
- clearJobWorkerHealth() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- clearJournalEntries() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
This journal entry is a list of other entries.
- clearJournalEntriesSinceCheckpoint() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
optional int64 journalEntriesSinceCheckpoint = 2;
- clearKey() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- clearKey() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string key = 1;
- clearKeys() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
repeated string keys = 2;
- clearLastAccessedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 last_accessed_ms = 30;
- clearLastAccessTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 lastAccessTimeMs = 31;
- clearLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 last_access_time_ms = 20;
- clearLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 last_access_time_ms = 29;
- clearLastAccessTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 last_access_time_ms = 18;
- clearLastCheckpointTime() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
optional int64 lastCheckpointTime = 1;
- clearLastContactSec() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int32 lastContactSec = 3;
- clearLastHeartbeatTime() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional int64 lastHeartbeatTime = 4;
- clearLastModificationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 lastModificationTimeMs = 14;
- clearLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- clearLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- clearLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
optional int64 last_modification_time_ms = 2;
- clearLastModificationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- clearLastModifiedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 last_modified_ms = 25;
- clearLastModifiedTimeMs() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional int64 last_modified_time_ms = 3;
- clearLastUpdated() - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 lastUpdated = 6;
- clearLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int64 lastUpdated = 3;
- clearLastUpdatedTime() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional int64 lastUpdatedTime = 5;
- clearLastUpdateMs() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 lastUpdateMs = 4;
- clearLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- clearLayout() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Layout layout = 6;
- clearLayout() - Method in class alluxio.grpc.table.Transformation.Builder
-
optional .alluxio.grpc.table.Layout layout = 1;
- clearLayoutData() - Method in class alluxio.grpc.table.Layout.Builder
-
optional bytes layout_data = 3;
- clearLayoutSpec() - Method in class alluxio.grpc.table.Layout.Builder
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- clearLayoutType() - Method in class alluxio.grpc.table.Layout.Builder
-
optional string layout_type = 1;
- clearLeaderMasterAddress() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string leaderMasterAddress = 1;
- clearLeastSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
-
optional int64 leastSignificantBits = 2;
- clearLeastSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
optional int64 leastSignificantBits = 2;
- clearLength() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int64 length = 5;
- clearLength() - Method in class alluxio.grpc.Block.Builder
-
The block length.
- clearLength() - Method in class alluxio.grpc.BlockInfo.Builder
-
optional int64 length = 2;
- clearLength() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int64 length = 5;
- clearLength() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the length of the block being committed
- clearLength() - Method in class alluxio.grpc.File.Builder
-
file length
- clearLength() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 length = 5;
- clearLength() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 length = 3;
- clearLength() - Method in class alluxio.grpc.Route.Builder
-
optional int64 length = 3;
- clearLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int64 length = 5;
- clearLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 length = 3;
- clearLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional int64 length = 2;
- clearLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 length = 3;
- clearLength() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 length = 9;
- clearLength() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 length = 2;
- clearLength() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 length = 3;
- clearLength() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
optional int64 length = 1;
- clearLength() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 length = 19;
- clearLiveWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 liveWorkerNum = 4;
- clearLoadAverage() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
repeated double loadAverage = 2;
- clearLoadDescendantType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
- clearLoadDirectChildren() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
This is deprecated since 1.1.1 and will be removed in 2.0.
- clearLoadJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- clearLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
No data will be transferred.
- clearLoadMetadataOnly() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
If set false, only the metadata of file will be loaded.
- clearLoadMetadataOnly() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool loadMetadataOnly = 4;
- clearLoadMetadataOnly() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional bool load_metadata_only = 9;
- clearLoadMetadataType() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- clearLoadMetadataType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- clearLoadMetadataType() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
- clearLoadPath() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string load_path = 1;
- clearLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
- clearLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool localFileSystem = 1;
- clearLocation() - Method in class alluxio.grpc.table.Database.Builder
-
optional string location = 3;
- clearLocation() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional string location = 2;
- clearLocations() - Method in class alluxio.grpc.BlockInfo.Builder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- clearLongestRunning() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- clearLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- clearLongType() - Method in class alluxio.grpc.table.Value.Builder
-
int64 long_type = 1;
- clearLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional int64 losePrimacyTimeMs = 3;
- clearLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional int64 losePrimacyTimeMs = 3;
- clearLostStorage() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- clearLostStorage() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- clearLostStorage() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- clearLostWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 lostWorkerNum = 5;
- clearLow() - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value low = 1;
- clearLowValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date low_value = 1;
- clearLowValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- clearLowValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional double low_value = 1;
- clearLowValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 low_value = 1;
- clearMaskActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- clearMasterAddress() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- clearMasterAddress() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- clearMasterAddress() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- clearMasterAddresses() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- clearMasterHostname() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
The hostname of the master that did the checkpoint
- clearMasterId() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
optional int64 masterId = 1;
- clearMasterId() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
optional int64 masterId = 1;
- clearMasterId() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional int64 masterId = 1;
- clearMasterId() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional int64 masterId = 1;
- clearMasterId() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional int64 masterId = 1;
- clearMasterInfo() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- clearMasterVersions() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- clearMaxColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional int64 max_col_len = 1;
- clearMaxColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 max_col_len = 1;
- clearMaxUfsReadConcurrency() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional int32 maxUfsReadConcurrency = 2;
- clearMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional int32 maxUfsReadConcurrency = 4;
- clearMediumType() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string mediumType = 4;
- clearMediumType() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string mediumType = 2;
- clearMediumType() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional string mediumType = 7;
- clearMediumType() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated string mediumType = 33;
- clearMediumType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional string medium_type = 2;
- clearMediumType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional string medium_type = 8;
- clearMediumType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
repeated string medium_type = 18;
- clearMediumType() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated string medium_type = 26;
- clearMediumType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
repeated string medium_type = 16;
- clearMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string mediumType = 3;
- clearMediumType() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated string medium_type = 27;
- clearMessage() - Method in class alluxio.grpc.BlockStatus.Builder
-
A developer-facing error message
- clearMessage() - Method in class alluxio.grpc.FileFailure.Builder
-
A developer-facing error message
- clearMessage() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
A developer-facing error message
- clearMessage() - Method in class alluxio.grpc.RouteFailure.Builder
-
A developer-facing error message
- clearMessage() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional bytes message = 2;
- clearMessage() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional bytes message = 3;
- clearMessage() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional string message = 2;
- clearMessageType() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
- clearMetrics(ClearMetricsRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
-
Clear the worker metrics.
- clearMetrics(ClearMetricsRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- clearMetrics() - Method in interface alluxio.client.metrics.MetricsMasterClient
-
Clear the master metrics.
- clearMetrics() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
-
- clearMetrics() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- clearMetrics(ClearMetricsRequest, StreamObserver<ClearMetricsResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
-
TODO(lu) Move to metrics worker
- clearMetrics(ClearMetricsRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
-
TODO(lu) Move to metrics worker
- clearMetrics(ClearMetricsRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
-
TODO(lu) Move to metrics worker
- clearMetrics(ClearMetricsRequest, StreamObserver<ClearMetricsResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
-
TODO(lu) Move to metrics worker
- clearMetrics() - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- clearMetrics() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- clearMetrics(ClearMetricsPRequest, StreamObserver<ClearMetricsPResponse>) - Method in interface alluxio.grpc.MetricsMasterClientServiceGrpc.AsyncService
-
Clears the metrics in the cluster.
- clearMetrics(ClearMetricsPRequest) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceBlockingStub
-
Clears the metrics in the cluster.
- clearMetrics(ClearMetricsPRequest) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceFutureStub
-
Clears the metrics in the cluster.
- clearMetrics(ClearMetricsPRequest, StreamObserver<ClearMetricsPResponse>) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceStub
-
Clears the metrics in the cluster.
- clearMetrics() - Method in class alluxio.master.metrics.DefaultMetricsMaster
-
- clearMetrics() - Method in interface alluxio.master.metrics.MetricsMaster
-
Clear metrics in the current master.
- clearMetrics(ClearMetricsPRequest, StreamObserver<ClearMetricsPResponse>) - Method in class alluxio.master.metrics.MetricsMasterClientServiceHandler
-
- clearMetrics() - Method in interface alluxio.worker.block.BlockWorker
-
Clears the worker metrics.
- ClearMetricsPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.ClearMetricsPRequest
- ClearMetricsPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.ClearMetricsPRequest
- ClearMetricsPRequestOrBuilder - Interface in alluxio.grpc
-
- ClearMetricsPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.ClearMetricsPResponse
- ClearMetricsPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.ClearMetricsPResponse
- ClearMetricsPResponseOrBuilder - Interface in alluxio.grpc
-
- ClearMetricsRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.ClearMetricsRequest
- ClearMetricsRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.ClearMetricsRequest
- ClearMetricsRequestOrBuilder - Interface in alluxio.grpc
-
- ClearMetricsResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.ClearMetricsResponse
- ClearMetricsResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.ClearMetricsResponse
- ClearMetricsResponseOrBuilder - Interface in alluxio.grpc
-
- clearMetricType() - Method in class alluxio.grpc.Metric.Builder
-
required .alluxio.grpc.MetricType metricType = 5;
- clearMetricType() - Method in class alluxio.grpc.MetricValue.Builder
-
optional .alluxio.grpc.MetricType metricType = 6;
- clearMode() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- clearMode() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- clearMode() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 mode = 18;
- clearMode() - Method in class alluxio.grpc.PAcl.Builder
-
optional int32 mode = 4;
- clearMode() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 5;
- clearMode() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional int32 mode = 6;
- clearMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional int32 mode = 4;
- clearMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int32 mode = 10;
- clearMode() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 mode = 16;
- clearMode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int32 mode = 11;
- clearMostSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
-
optional int64 mostSignificantBits = 1;
- clearMostSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
optional int64 mostSignificantBits = 1;
- clearMountId() - Method in class alluxio.grpc.Block.Builder
-
optional int64 mountId = 5;
- clearMountId() - Method in class alluxio.grpc.File.Builder
-
optional int64 mountId = 4;
- clearMountId() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 mountId = 23;
- clearMountId() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
required int64 mountId = 1;
- clearMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
the id of the ufs
- clearMountId() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 mountId = 8;
- clearMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional int64 mount_id = 5;
- clearMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional int64 mountId = 5;
- clearMountId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
optional int64 mount_id = 1;
- clearMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional int64 mount_id = 6;
- clearMountId() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
optional int64 mount_id = 2;
- clearMountId() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
optional int64 mount_id = 2;
- clearMountPoint() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool mountPoint = 20;
- clearMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool mount_point = 11;
- clearMountPoint() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional bool mount_point = 2;
- clearMountPoints() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- clearMoveJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- clearMsg() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
optional string msg = 1;
- clearName() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string name = 1;
- clearName() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string name = 2;
- clearName() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
optional string name = 1;
- clearName() - Method in class alluxio.grpc.JobInfo.Builder
-
Some jobs don't have these
- clearName() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional string name = 2;
- clearName() - Method in class alluxio.grpc.Metric.Builder
-
optional string name = 3;
- clearName() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional string name = 2;
- clearName() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string name = 2;
- clearName() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string name = 1;
- clearName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string name = 3;
- clearName() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string name = 3;
- clearName() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string name = 3;
- clearName() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string name = 1;
- clearName() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional string name = 2;
- clearName() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
optional string name = 1;
- clearName() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string name = 6;
- clearName() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional string name = 1;
- clearNewBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- clearNewName() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_name = 5;
- clearNewParentId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 new_parent_id = 4;
- clearNewPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_path = 7;
- clearNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
optional int64 next_container_id = 1;
- clearNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
If set, do not try to cache the block locally when reading the data from the UFS.
- clearNodeState() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
optional .alluxio.grpc.journal.NodeState node_state = 1;
- clearNumActiveTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 numActiveTasks = 6;
- clearNumDistincts() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- clearNumDistincts() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- clearNumDistincts() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- clearNumDistincts() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- clearNumDistincts() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- clearNumFalses() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_falses = 2;
- clearNumNulls() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- clearNumNulls() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- clearNumNulls() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- clearNumNulls() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- clearNumNulls() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- clearNumNulls() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- clearNumNulls() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- clearNumTrues() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_trues = 1;
- clearOffset() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional int64 offset = 2;
- clearOffset() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 offset = 2;
- clearOffset() - Method in class alluxio.grpc.SnapshotData.Builder
-
Deprecated.
- clearOffset() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional int64 offset = 3;
- clearOffset() - Method in class alluxio.grpc.WriteResponse.Builder
-
optional int64 offset = 1;
- clearOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 offset = 2;
- clearOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional int64 offset = 3;
- clearOffsetCount() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Only start listing items after this many items have been processed.
- clearOffsetId() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Start listing after the given FileId, the FileId can be calculated from the
result of a previous listing's FileInfo or URIStatus results using the
getFileId method.
- clearOffsetInFile() - Method in class alluxio.grpc.Block.Builder
-
The offset of the block in within ufs the file.
- clearOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The offset of the block in within the file.
- clearOffsetReceived() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- clearOffsetReceived() - Method in class alluxio.grpc.ReadRequest.Builder
-
Read receipt
- clearOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- clearOffsetType() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ActionInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupPStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Block.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockIdList.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockLocation.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BuildVersion.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CacheRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CacheResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Chunk.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClientMetrics.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CmdProgress.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CmdSummary.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Command.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ConfigProperties.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ConfigProperty.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CopyRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CopyResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DeletePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DeletePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DeletePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ErrorInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ExistsPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ExistsPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ExistsPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.File.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileFailure.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemCommand.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FreePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FreePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FreePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FsOpPId.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
Deprecated.
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.InconsistentProperties.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobCommand.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobDescription.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobProgress.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobUnused.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListAllPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MasterInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MasterVersion.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Metric.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MetricValue.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MountPointInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MountPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MountPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MountPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MoveBlockResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MoveRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MoveResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NetAddress.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PAcl.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PAclEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PersistFile.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PMode.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PolicyInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PolicyStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ProxyStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ReadRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ReadResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterCommand.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RenamePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RenamePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RenamePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RetryInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Route.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RouteFailure.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RunPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RunPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RunPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RunTaskCommand.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SaslMessage.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAclPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAclPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAttributePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SnapshotData.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StatusSummary.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StopJobPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StopJobPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StorageList.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SubmitOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SubmitRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SubmitResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Constraint.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Database.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Date.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Decimal.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Domain.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Layout.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Partition.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Range.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.RangeSet.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Schema.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.TableInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Transformation.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Value.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TierList.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransportMessage.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UfsFileStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UfsInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UfsStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UnmountPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UnmountPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UnmountPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WorkerIdentity.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WorkerInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WriteOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WriteRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WriteResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
- clearOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
If set, only reserve space for the block.
- clearOpenUfsBlockOptions() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- clearOpenUfsBlockOptions() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- clearOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest.Builder
-
This is only set for UFS block read.
- clearOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- clearOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
This is only set for UFS block read.
- clearOperation() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string operation = 1;
- clearOperationId() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- clearOperationId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- clearOperationType() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
optional .alluxio.grpc.job.OperationType operationType = 3;
- clearOperationType() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.OperationType operationType = 2;
- clearOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 op_time_ms = 4;
- clearOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional int64 op_time_ms = 3;
- clearOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 op_time_ms = 3;
- clearOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 op_time_ms = 3;
- clearOpTimeMs() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional int64 op_time_ms = 2;
- clearOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 op_time_ms = 2;
- clearOptions() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- clearOptions() - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- clearOptions() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.DeletePRequest.Builder
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.FreePRequest.Builder
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- clearOptions() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- clearOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.ListAllPRequest.Builder
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.LoadRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.MountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- clearOptions() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- clearOptions() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.RenamePRequest.Builder
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.RunPRequest.Builder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the method options
- clearOptions() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- clearOptions() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- clearOptions() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- clearOrder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
- clearOtherActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- clearOtherBits() - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits otherBits = 3;
- clearOutputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string output_format = 3;
- clearOverwrite() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool overwrite = 4;
- clearOverwrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool overwrite = 13;
- clearOverwrite() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool overwrite = 4;
- clearOverwrite() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
optional bool overwrite = 1;
- clearOverwrite() - Method in class alluxio.grpc.WriteOptions.Builder
-
optional bool overwrite = 1;
- clearOverwrite() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional bool overwrite = 10;
- clearOverwrite() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional bool overwrite = 10;
- clearOverwriteAccessTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool overwrite_access_time = 19;
- clearOverwriteModificationTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool overwrite_modification_time = 8;
- clearOwner() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string owner = 16;
- clearOwner() - Method in class alluxio.grpc.PAcl.Builder
-
optional string owner = 1;
- clearOwner() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string owner = 3;
- clearOwner() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string owner = 4;
- clearOwner() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string owner = 4;
- clearOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string owner = 2;
- clearOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string owner = 8;
- clearOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string owner = 14;
- clearOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string owner = 6;
- clearOwner() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string owner = 9;
- clearOwnerBits() - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits ownerBits = 1;
- clearOwnerName() - Method in class alluxio.grpc.table.Database.Builder
-
optional string owner_name = 5;
- clearOwnerType() - Method in class alluxio.grpc.table.Database.Builder
-
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
- clearOwningGroup() - Method in class alluxio.grpc.PAcl.Builder
-
optional string owningGroup = 2;
- clearOwningGroup() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningGroup = 2;
- clearOwningUser() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningUser = 1;
- clearPageSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional int64 pageSize = 1;
- clearParameter() - Method in class alluxio.grpc.table.Database.Builder
-
- clearParameters() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- clearParameters() - Method in class alluxio.grpc.table.TableInfo.Builder
-
- clearParentId() - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 parentId = 10;
- clearParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 parent_id = 2;
- clearParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 parent_id = 2;
- clearParentId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 parent_id = 2;
- clearParentId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 parent_id = 7;
- clearPartialListing() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool partialListing = 3;
- clearPartialListing() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool partialListing = 3;
- clearPartialListing() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool partialListing = 3;
- clearPartialListing() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required bool partialListing = 7;
- clearPartialListing() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required bool partialListing = 6;
- clearPartialListing() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required bool partialListing = 7;
- clearPartitionCols() - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- clearPartitionName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
partition name in the form of "key=value"
- clearPartitions() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- clearPartitionSpec() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- clearPartitionStatistics() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- clearPartNames() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string part_names = 4;
- clearPath() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional string path = 1;
- clearPath() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
the root of the subtree to check
- clearPath() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
the path of the file
- clearPath() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
the path of the directory
- clearPath() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
the path of the file
- clearPath() - Method in class alluxio.grpc.DeletePRequest.Builder
-
the path of the file or directory
- clearPath() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional string path = 1;
- clearPath() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string path = 3;
- clearPath() - Method in class alluxio.grpc.FreePRequest.Builder
-
the path of the file or directory
- clearPath() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
optional string path = 1;
- clearPath() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
the path of the file
- clearPath() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
the path of the file or directory
- clearPath() - Method in class alluxio.grpc.JobDescription.Builder
-
optional string path = 2;
- clearPath() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
the path of the file or directory
- clearPath() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
the path of the file or directory
- clearPath() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
required string path = 1;
- clearPath() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional string path = 1;
- clearPath() - Method in class alluxio.grpc.RenamePRequest.Builder
-
the source path of the file or directory
- clearPath() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
the path of the file
- clearPath() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the path of the file or directory
- clearPath() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
the path of the file
- clearPath() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional string path = 1;
- clearPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
optional string path = 1;
- clearPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
optional string path = 1;
- clearPath() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional string path = 5;
- clearPath() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string path = 17;
- clearPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string path = 25;
- clearPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string path = 6;
- clearPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string path = 12;
- clearPath() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
optional string path = 1;
- clearPath() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
optional string path = 1;
- clearPathConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string pathConfigHash = 2;
- clearPathConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string pathConfigHash = 4;
- clearPathConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional int64 pathConfigLastUpdateTime = 6;
- clearPathConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- clearPathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- clearPattern() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
optional string pattern = 2;
- clearPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 permission = 8;
- clearPersist() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional bool persist = 2;
- clearPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- clearPersisted() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool persisted = 12;
- clearPersisted() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool persisted = 2;
- clearPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional bool persisted = 5;
- clearPersistedFileFingerprints() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
repeated string persistedFileFingerprints = 1;
- clearPersistedFiles() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
the list of persisted files
- clearPersistenceState() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string persistenceState = 19;
- clearPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string persistence_state = 4;
- clearPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string persistence_state = 4;
- clearPersistenceState() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string persistence_state = 4;
- clearPersistenceState() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persistence_state = 8;
- clearPersistenceWaitTime() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int64 persistenceWaitTime = 10;
- clearPersistenceWaitTime() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional int64 persistenceWaitTime = 2;
- clearPersistFiles() - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- clearPersistJobId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 persist_job_id = 22;
- clearPersistJobId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 persistJobId = 11;
- clearPersistJobId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 persist_job_id = 10;
- clearPersistJobId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
Used for recovering in-progress file persist jobs on master start.
- clearPersistJobTempUfsPath() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persist_job_temp_ufs_path = 24;
- clearPersistOptions() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- clearPinned() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool pinned = 10;
- clearPinned() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool pinned = 1;
- clearPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool pinned = 5;
- clearPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool pinned = 5;
- clearPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional bool pinned = 3;
- clearPinned() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool pinned = 5;
- clearPinnedFileIds() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
TODO(adit): set replacement?
- clearPinnedMedia() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
repeated string pinnedMedia = 10;
- clearPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional bool pin_on_create = 9;
- clearPolicy() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- clearPolicy() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- clearPolicyDefinition() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- clearPolicyName() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional string policyName = 1;
- clearPolicyName() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string policyName = 1;
- clearPolicyName() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional string policyName = 1;
- clearPolicyName() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional string policyName = 1;
- clearPolicyName() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
optional string policyName = 1;
- clearPolicyRemove() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- clearPositionShort() - Method in class alluxio.grpc.ReadRequest.Builder
-
Is position read to a small buffer
- clearPositionShort() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
is position short or not, used for HDFS performance optimization.
- clearPrefix() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Only match files with a given prefix.
- clearPreviousVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 previous_version = 9;
- clearPriority() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional int32 priority = 4;
- clearProgressPercentage() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional float progressPercentage = 9;
- clearProgressReport() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
optional string progressReport = 1;
- clearPromote() - Method in class alluxio.grpc.ReadRequest.Builder
-
Whether the block should be promoted before reading
- clearPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
optional bool promote = 2;
- clearPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
Whether the block should be promoted before reading
- clearProperties() - Method in class alluxio.grpc.ConfigProperties.Builder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- clearProperties() - Method in class alluxio.grpc.InconsistentProperties.Builder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- clearProperties() - Method in class alluxio.grpc.MountPointInfo.Builder
-
- clearProperties() - Method in class alluxio.grpc.MountPOptions.Builder
-
- clearProperties() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- clearProperties() - Method in class alluxio.grpc.UfsInfo.Builder
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- clearProperties() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- clearProperties() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- clearProperties() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- clearProxyAddress() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- clearProxyStatuses() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- clearRaftAddress() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated string raftAddress = 13;
- clearRaftJournal() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional bool raftJournal = 12;
- clearRange() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.RangeSet range = 1;
- clearRanges() - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- clearRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool rawValue = 1;
- clearReadOnly() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional bool readOnly = 5;
- clearReadOnly() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional bool readOnly = 1;
- clearReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional bool readOnly = 3;
- clearReadType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.ReadPType readType = 1;
- clearRecentActivities() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- clearRecentFailures() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- clearRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool recursive = 1;
- clearRecursive() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool recursive = 2;
- clearRecursive() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool recursive = 1;
- clearRecursive() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional bool recursive = 1;
- clearRecursive() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional bool recursive = 4;
- clearRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
whether to load metadata recursively
- clearRecursive() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional bool recursive = 2;
- clearRecursive() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool recursive = 6;
- clearRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
Deprecated, we now write one journal entry per inode removed
- clearRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional bool recursive = 5;
- clearRegisterCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- clearRemovedBlockIds() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the list of removed block ids
- clearRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- clearRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- clearRename() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- clearReplicationDurable() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationDurable = 6;
- clearReplicationDurable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_durable = 24;
- clearReplicationDurable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_durable = 20;
- clearReplicationMax() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationMax = 4;
- clearReplicationMax() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 replicationMax = 29;
- clearReplicationMax() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional int32 replicationMax = 7;
- clearReplicationMax() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_max = 20;
- clearReplicationMax() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 replication_max = 13;
- clearReplicationMax() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int32 replication_max = 8;
- clearReplicationMax() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_max = 21;
- clearReplicationMin() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationMin = 5;
- clearReplicationMin() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 replicationMin = 30;
- clearReplicationMin() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional int32 replicationMin = 8;
- clearReplicationMin() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_min = 21;
- clearReplicationMin() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 replication_min = 14;
- clearReplicationMin() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int32 replication_min = 9;
- clearReplicationMin() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_min = 22;
- clearReport() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- clearRequestBody() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
optional bytes request_body = 1;
- clearRequestHeader() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- clearRequestId() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
optional int64 requestId = 1;
- clearRequestId() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
optional int64 requestId = 1;
- clearResponseHeader() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- clearResult() - Method in class alluxio.grpc.JobInfo.Builder
-
optional bytes result = 9;
- clearRetryable() - Method in class alluxio.grpc.BlockStatus.Builder
-
optional bool retryable = 4;
- clearRetryable() - Method in class alluxio.grpc.FileFailure.Builder
-
optional bool retryable = 4;
- clearRetryable() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional bool retryable = 4;
- clearRetryable() - Method in class alluxio.grpc.RouteFailure.Builder
-
optional bool retryable = 4;
- clearRevision() - Method in class alluxio.grpc.BuildVersion.Builder
-
the git revision at the time of building
- clearRevision() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string revision = 5;
- clearRoute() - Method in class alluxio.grpc.RouteFailure.Builder
-
required .alluxio.grpc.block.Route route = 1;
- clearRoutes() - Method in class alluxio.grpc.CopyRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- clearRoutes() - Method in class alluxio.grpc.MoveRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- clearRpcPort() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int32 rpcPort = 3;
- clearRpcPort() - Method in class alluxio.grpc.NetAddress.Builder
-
optional int32 rpcPort = 2;
- clearRpcPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 rpcPort = 2;
- clearRunAsync() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool runAsync = 2;
- clearRunTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- clearS3SyntaxOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- clearSafeMode() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional bool safeMode = 4;
- clearScale() - Method in class alluxio.grpc.table.Decimal.Builder
-
force using scale first in Decimal.compareTo
- clearScanCompleted() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanCompleted = 4;
- clearScanPendingAction() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanPendingAction = 3;
- clearScanStartedMs() - Method in class alluxio.grpc.PolicyStatus.Builder
-
scan status
- clearScanTotal() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanTotal = 2;
- clearSchema() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Schema schema = 5;
- clearSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
optional int64 sequence_number = 2;
- clearSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
shared fields.
- clearSerde() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string serde = 1;
- clearSerdelibParameters() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- clearSerdeParameters() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- clearServerAddress() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- clearServerAddress() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- clearServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- clearServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- clearServerInfo() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- clearServerState() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
- clearServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
The purpose of this field is to make grpc service on standby masters work without
making client changes and keeps backwards compatibility.
- clearSetAcl() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- clearSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- clearSetBlocks() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
Overwrite the blocks list
- clearSetTaskPoolSizeCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- clearShared() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional bool shared = 7;
- clearShared() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional bool shared = 3;
- clearShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional bool shared = 5;
- clearShouldPersistTime() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 should_persist_time = 27;
- clearShouldPersistTime() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 should_persist_time = 28;
- clearSkewed() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional bool skewed = 4;
- clearSkipIfExists() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
optional bool skip_if_exists = 4;
- clearSkipIfExists() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool skipIfExists = 5;
- clearSkipIfExists() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional bool skip_if_exists = 10;
- clearSnapshotIndex() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional int64 snapshotIndex = 2;
- clearSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional int64 snapshotIndex = 2;
- clearSnapshotInfo() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- clearSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- clearSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- clearSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- clearSnapshotTerm() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional int64 snapshotTerm = 1;
- clearSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional int64 snapshotTerm = 1;
- clearSortedBy() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- clearSource() - Method in class alluxio.grpc.ClientMetrics.Builder
-
optional string source = 1;
- clearSource() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string source = 2;
- clearSource() - Method in class alluxio.grpc.Metric.Builder
-
optional string source = 2;
- clearSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- clearSourceHost() - Method in class alluxio.grpc.CacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- clearSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- clearSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int32 source_port = 3;
- clearSourcePort() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int32 source_port = 3;
- clearSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int32 source_port = 3;
- clearSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional int64 space_to_reserve = 10;
- clearSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int64 space_to_reserve = 4;
- clearSpec() - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
optional string spec = 1;
- clearSpec() - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
optional string spec = 1;
- clearSrc() - Method in class alluxio.grpc.Route.Builder
-
required string src = 1;
- clearSrc() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string src = 1;
- clearSrc() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string src = 1;
- clearSrcPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string srcPath = 2;
- clearStartAfter() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Start the listing after this path.
- clearStartTime() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional int64 startTime = 3;
- clearStartTime() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional int64 startTime = 2;
- clearStartTime() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional int64 startTime = 3;
- clearStartTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int64 startTimeMs = 5;
- clearStartTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional int64 startTimeMs = 2;
- clearStartTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional int64 startTimeMs = 2;
- clearStartTimeMs() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 startTimeMs = 7;
- clearState() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional string state = 1;
- clearState() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string state = 3;
- clearState() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional string state = 2;
- clearState() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional string state = 4;
- clearState() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 3;
- clearState() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 2;
- clearState() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 3;
- clearStatistics() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- clearStatistics() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- clearStats() - Method in class alluxio.grpc.table.Layout.Builder
-
- clearStatus() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.Status status = 4;
- clearStatus() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
optional .alluxio.grpc.meta.ConfigStatus status = 3;
- clearStatus() - Method in class alluxio.grpc.CopyResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- clearStatus() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- clearStatus() - Method in class alluxio.grpc.JobInfo.Builder
-
optional .alluxio.grpc.job.Status status = 4;
- clearStatus() - Method in class alluxio.grpc.JobProgress.Builder
-
optional .alluxio.grpc.job.Status status = 7;
- clearStatus() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
repeated .alluxio.grpc.job.Status status = 1;
- clearStatus() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- clearStatus() - Method in class alluxio.grpc.LoadResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- clearStatus() - Method in class alluxio.grpc.MoveResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- clearStatus() - Method in class alluxio.grpc.StatusSummary.Builder
-
optional .alluxio.grpc.job.Status status = 1;
- clearStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- clearStatus() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- clearStatus() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional .alluxio.proto.status.PStatus status = 1;
- clearStorage() - Method in class alluxio.grpc.StorageList.Builder
-
a lost storage path
- clearStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- clearStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- clearStorageTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the list of storage tiers
- clearStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- clearStringType() - Method in class alluxio.grpc.table.Value.Builder
-
string string_type = 3;
- clearStringValue() - Method in class alluxio.grpc.MetricValue.Builder
-
optional string stringValue = 2;
- clearSubject() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional string subject = 2;
- clearSubject() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional string subject = 2;
- clearSubmissionTime() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 submissionTime = 5;
- clearSuccess() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
TODO(gpang): remove in favor of status
- clearSuccess() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
optional bool success = 1;
- clearSuccess() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
TODO(gpang): remove in favor of status
- clearSummary() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- clearSummaryPerStatus() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- clearSyncIntervalMs() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional int64 syncIntervalMs = 1;
- clearSyncParentNextTime() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool syncParentNextTime = 5;
- clearSyncpointPath() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- clearSyncpointPath() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- clearSyncStatus() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- clearTable() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
repeated string table = 1;
- clearTableInfo() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- clearTableName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- clearTableName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- clearTableName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string table_name = 2;
- clearTableName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string table_name = 4;
- clearTableName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string table_name = 2;
- clearTableName() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string table_name = 2;
- clearTableName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string table_name = 2;
- clearTableName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string table_name = 2;
- clearTablesErrors() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- clearTablesIgnored() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_ignored = 2;
- clearTablesRemoved() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_removed = 5;
- clearTablesUnchanged() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_unchanged = 3;
- clearTablesUpdated() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_updated = 4;
- clearTag() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
required string tag = 1;
- clearTags() - Method in class alluxio.grpc.Metric.Builder
-
- clearTargetDirectory() - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional string targetDirectory = 2;
- clearTaskArgs() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional bytes taskArgs = 4;
- clearTaskId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
optional int64 taskId = 2;
- clearTaskId() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional int64 taskId = 2;
- clearTaskInfos() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- clearTaskPoolSize() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 taskPoolSize = 5;
- clearTaskPoolSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
optional int32 taskPoolSize = 1;
- clearTempUfsPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string temp_ufs_path = 23;
- clearTempUfsPath() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string tempUfsPath = 12;
- clearTempUfsPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string temp_ufs_path = 11;
- clearThreads() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
repeated string threads = 1;
- clearThroughput() - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
-
removes the list of all throughput after worker aggregation.
- clearTier() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
This is only applicable for block write.
- clearTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int32 tier = 3;
- clearTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for block write.
- clearTier() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string tier = 2;
- clearTierAlias() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string tierAlias = 3;
- clearTierAlias() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string tierAlias = 1;
- clearTierAlias() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the alias of the target tier
- clearTiers() - Method in class alluxio.grpc.TierList.Builder
-
repeated int64 tiers = 1;
- clearTimeExpression() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string timeExpression = 4;
- clearTimer(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
-
Removes a timer name from the scheduler if it exists.
- clearTotalBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- clearTransferId() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
required string transferId = 1;
- clearTransferId() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
required string transferId = 1;
- clearTransformations() - Method in class alluxio.grpc.table.Partition.Builder
-
The latest transformation is in the back of the list.
- clearTransMsg() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- clearTs() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
the timestamp in nanoseconds when this FileStatus is refreshed
- clearTtl() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 ttl = 15;
- clearTtl() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional int64 ttl = 2;
- clearTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 ttl = 13;
- clearTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 ttl = 13;
- clearTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 ttl = 4;
- clearTtl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 ttl = 12;
- clearTtl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 ttl = 4;
- clearTtlAction() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.TtlAction ttlAction = 22;
- clearTtlAction() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.TtlAction ttlAction = 3;
- clearTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
- clearTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
- clearTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
- clearTtlAction() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
- clearTtlAction() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.grpc.TtlAction ttl_action = 5;
- clearTxId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
optional int64 tx_id = 2;
- clearType() - Method in class alluxio.grpc.JobDescription.Builder
-
required string type = 1;
- clearType() - Method in class alluxio.grpc.JobInfo.Builder
-
optional .alluxio.grpc.job.JobType type = 8;
- clearType() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional .alluxio.grpc.file.PAclEntryType type = 1;
- clearType() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string type = 3;
- clearType() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
- clearType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional .alluxio.grpc.block.RequestType type = 1;
- clearType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
- clearType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional .alluxio.proto.dataserver.RequestType type = 1;
- clearType() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional .alluxio.proto.shared.AclEntryType type = 1;
- clearUdbConnectionUri() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_connection_uri = 2;
- clearUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_db_name = 3;
- clearUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_type = 1;
- clearUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 ufsCapacityBytes = 3 [default = -1];
- clearUfsFileStatus() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- clearUfsFingerprint() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsFingerprint = 26;
- clearUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional string ufs_fingerprint = 5;
- clearUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string ufs_fingerprint = 18;
- clearUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string ufs_fingerprint = 10;
- clearUfsFingerprint() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string ufs_fingerprint = 15;
- clearUfsFingerprint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string ufs_fingerprint = 11;
- clearUfsFullPath() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string ufs_full_path = 8;
- clearUfsInfo() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- clearUfsLength() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional int64 ufsLength = 1;
- clearUfsLocations() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- clearUfsMode() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
- clearUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
- clearUfsPath() - Method in class alluxio.grpc.Block.Builder
-
optional string ufs_path = 3;
- clearUfsPath() - Method in class alluxio.grpc.File.Builder
-
optional string ufs_path = 2;
- clearUfsPath() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsPath = 4;
- clearUfsPath() - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of the under file system
- clearUfsPath() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
the ufs path
- clearUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string ufs_path = 1;
- clearUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional string ufs_path = 1;
- clearUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string ufs_path = 2;
- clearUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
optional string ufsPath = 1;
- clearUfsReadOptions() - Method in class alluxio.grpc.CopyRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- clearUfsReadOptions() - Method in class alluxio.grpc.MoveRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- clearUfsReadWorkerLocation() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- clearUfsStatus() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- clearUfsStatus() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- clearUfsStringLocations() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
repeated string ufsStringLocations = 4;
- clearUfsType() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsType = 35;
- clearUfsType() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsType = 2;
- clearUfsUri() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
required string ufsUri = 1;
- clearUfsUri() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsUri = 1;
- clearUfsUri() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
optional string ufsUri = 1;
- clearUfsUsedBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 ufsUsedBytes = 4 [default = -1];
- clearUnchecked() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool unchecked = 3;
- clearUnfinishedTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 unfinishedTasks = 7;
- clearUnscaled() - Method in class alluxio.grpc.table.Decimal.Builder
-
required bytes unscaled = 2;
- clearUnused0() - Method in class alluxio.grpc.JobInfo.Builder
-
Around for backwards compatibility
- clearUnused1() - Method in class alluxio.grpc.JobInfo.Builder
-
formerly result
- clearUpdateInode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- clearUpdateInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- clearUpdateInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- clearUpdateLastAccessTime() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional bool updateLastAccessTime = 4 [default = true];
- clearUpdateTimestamps() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional bool updateTimestamps = 4 [default = true];
- clearUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- clearUpTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int64 upTimeMs = 6;
- clearUri() - Method in class alluxio.grpc.UfsInfo.Builder
-
optional string uri = 1;
- clearUsedBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 usedBytes = 6;
- clearUsedBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 usedBytes = 6;
- clearUsedBytesOnTier() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the space used in bytes on the target tier
- clearUsedBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- clearUsedBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- clearUsedBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- clearUsedBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
-
- clearUseMultipartUpload() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool useMultipartUpload = 17;
- clearUser() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
optional string user = 4;
- clearUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The client does not need to set this.
- clearUser() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional string user = 6;
- clearUser() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional string user = 5;
- clearUser() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional string user = 6;
- clearUserActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- clearUuid() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional string uuid = 3;
- clearUuid() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
uuid of its open file handle
- clearValue() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string value = 3;
- clearValue() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- clearValue() - Method in class alluxio.grpc.Metric.Builder
-
optional double value = 4;
- clearValue() - Method in class alluxio.grpc.table.Value.Builder
-
- clearValue() - Method in class alluxio.grpc.WriteRequest.Builder
-
- clearValue() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string value = 2;
- clearValue() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string value = 3;
- clearValues() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- clearValues() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
repeated string values = 1;
- clearValues() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
list of string values for each partition column
- clearValueSet() - Method in class alluxio.grpc.table.Domain.Builder
-
- clearVerbose() - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
optional bool verbose = 2;
- clearVerify() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool verify = 2;
- clearVerify() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool verify = 2;
- clearVerify() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool verify = 2;
- clearVerify() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required bool verify = 5;
- clearVerify() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required bool verify = 4;
- clearVerify() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required bool verify = 5;
- clearVersion() - Method in class alluxio.grpc.BuildVersion.Builder
-
the project version
- clearVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
optional int64 version = 1;
- clearVersion() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- clearVersion() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional .alluxio.grpc.BuildVersion version = 8;
- clearVersion() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string version = 7;
- clearVersion() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string version = 2;
- clearVersion() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- clearVersion() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 5;
- clearVersion() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- clearVersion() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- clearVersion() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string version = 4;
- clearVersion() - Method in class alluxio.grpc.table.Partition.Builder
-
optional int64 version = 4;
- clearVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 version = 10;
- clearVersion() - Method in class alluxio.grpc.WorkerIdentity.Builder
-
version of the definition of the opaque identifier
- clearVersionCreationTime() - Method in class alluxio.grpc.table.Partition.Builder
-
optional int64 version_creation_time = 5;
- clearVersionCreationTime() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 version_creation_time = 11;
- clearWarns() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- clearWebPort() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int32 webPort = 8;
- clearWebPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 webPort = 4;
- clearWhiteList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
optional bool white_list = 2;
- clearWorkerAddress() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- clearWorkerAddresses() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- clearWorkerHealths() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- clearWorkerHost() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string workerHost = 12;
- clearWorkerHostname() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
required string workerHostname = 1;
- clearWorkerHostname() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
required string workerHostname = 1;
- clearWorkerId() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the id of the worker
- clearWorkerId() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional int64 workerId = 1;
- clearWorkerId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the id of the worker
- clearWorkerId() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
the id of the worker
- clearWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
optional int64 workerId = 1;
- clearWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional int64 workerId = 1;
- clearWorkerId() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
optional int64 workerId = 1;
- clearWorkerId() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int64 workerId = 1;
- clearWorkerId() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional int64 workerId = 1;
- clearWorkerId() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the id of the worker
- clearWorkerId() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional int64 worker_id = 1;
- clearWorkerInfos() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- clearWorkerLocation() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
If specified, the data will be written to the certain worker
- clearWorkerLostStorageInfo() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- clearWorkerNetAddress() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
the worker network address
- clearWorkerNetAddress() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
the worker network address
- clearWorkerNetAddress() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- clearWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
- clearWorkerWebPort() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
optional int64 workerWebPort = 2;
- clearWorkerWebPort() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
optional int64 workerWebPort = 2;
- clearWriteOptions() - Method in class alluxio.grpc.CopyRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- clearWriteOptions() - Method in class alluxio.grpc.MoveRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- clearWriteTier() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 writeTier = 7;
- clearWriteType() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- clearWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
- clearWriteType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
- clearWriteType() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- clearWriteType() - Method in class alluxio.grpc.WriteOptions.Builder
-
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
- clearXattr() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- clearXattr() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- clearXattr() - Method in class alluxio.grpc.FileInfo.Builder
-
- clearXattr() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- clearXattr() - Method in class alluxio.grpc.UfsStatus.Builder
-
- clearXAttr() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- clearXAttr() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- clearXAttr() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- clearXAttr() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- clearXattrPropStrat() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
- clearXattrPropStrat() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
- clearXattrUpdateStrategy() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
- clearXAttrUpdateStrategy() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
- clearZookeeperAddresses() - Method in class alluxio.grpc.MasterInfo.Builder
-
Empty means zookeeper is not enabled
- CLI_VALUE - Static variable in enum alluxio.grpc.JobSource
-
CLI = 1;
- CliConfig - Interface in alluxio.job.cmd
-
A Cmd config for Cli.
- Client - Interface in alluxio
-
Interface for a client in the Alluxio system.
- client() - Method in class alluxio.master.transport.GrpcMessagingTransport
-
Creates a new Grpc messaging client.
- CLIENT_BLOCK_MASTER_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BLOCK_READ_CHUNK_REMOTE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BLOCK_WORKER_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BUSY_EXCEPTION_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BYTES_READ_FROM_UFS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BYTES_READ_FROM_WORKERS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BYTES_WRITTEN_TO_UFS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BYTES_WRITTEN_TO_WORKERS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_DISCARDED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_EVICTED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_READ_CACHE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_READ_EXTERNAL - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_READ_IN_STREAM_BUFFER - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_REQUESTED_EXTERNAL - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_WRITTEN_CACHE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_CLEAN_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_CLEANUP_GET_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_CLEANUP_PUT_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_CREATE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_DELETE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_DELETE_FROM_STORE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_DELETE_NON_EXISTING_PAGE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_DELETE_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_EXTERNAL_REQUESTS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_GET_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_GET_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_GET_STORE_READ_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_HIT_RATE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_HIT_REQUESTS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGE_READ_CACHE_TIME_NS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGE_READ_EXTERNAL_TIME_NS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGES - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGES_AGES - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGES_DISCARDED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGES_EVICTED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGES_INVALIDATED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_POSITION_READ_FALLBACK - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_ASYNC_REJECTION_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_BENIGN_RACING_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_EVICTION_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_INSUFFICIENT_SPACE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_STORE_DELETE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_STORE_WRITE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_STORE_WRITE_NO_SPACE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_BYTES - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_BYTES_HIT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_BYTES_READ - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_FALSE_POSITIVE_RATIO - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_PAGES - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_PAGES_HIT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_PAGES_READ - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SPACE_AVAILABLE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SPACE_USED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SPACE_USED_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_STATE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_STORE_DELETE_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_STORE_GET_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_STORE_PUT_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_STORE_THREADS_REJECTED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_DEFAULT_HIVE_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_FILE_SYSTEM_MASTER_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_META_DATA_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_TYPE_OPTION_NAME - Static variable in class alluxio.stress.common.FileSystemParameters
-
- CLIENT_UFS_FALLBACK_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_UFS_FALLBACK_READ_BYTES - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_VALUE - Static variable in enum alluxio.grpc.Scope
-
CLIENT = 4;
- CLIENT_WRITE_TO_UFS_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- CLIENT_WRITE_TO_UFS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- clientClosed(BlockClient, BlockStoreLocation) - Method in interface alluxio.worker.block.io.BlockClientListener
-
Called when an open block client is closed.
- ClientContext - Class in alluxio
-
A
ClientContext
contains information required and pertaining to making network
connections and performing operations with remote Alluxio processes.
- ClientContext(ClientContext) - Constructor for class alluxio.ClientContext
-
This constructor does not create a copy of the configuration.
- ClientContext(Subject, AlluxioConfiguration) - Constructor for class alluxio.ClientContext
-
- ClientContextServerInjector - Class in alluxio.security.authentication
-
Server side interceptor that is used to put remote client's IP Address to thread local storage.
- ClientContextServerInjector() - Constructor for class alluxio.security.authentication.ClientContextServerInjector
-
- clientHeartbeat(String, List<Metric>) - Method in class alluxio.master.metrics.DefaultMetricsMaster
-
- clientHeartbeat(String, List<Metric>) - Method in interface alluxio.master.metrics.MetricsMaster
-
Handles the client's heartbeat request for metrics collection.
- CLIENTID_FIELD_NUMBER - Static variable in class alluxio.grpc.SaslMessage
-
- ClientIOOperation - Enum in alluxio.stress.client
-
The operations for the client io stress tests.
- ClientIOOperationConverter() - Constructor for class alluxio.stress.client.ClientIOParameters.ClientIOOperationConverter
-
- ClientIOParameters - Class in alluxio.stress.client
-
This holds all the parameters.
- ClientIOParameters() - Constructor for class alluxio.stress.client.ClientIOParameters
-
- ClientIOParameters.ClientIOOperationConverter - Class in alluxio.stress.client
-
Converts from String to ClientIOOperation instance.
- ClientIOSummary - Class in alluxio.stress.client
-
The summary for Fuse IO stress bench.
- ClientIOSummary() - Constructor for class alluxio.stress.client.ClientIOSummary
-
Default constructor required for json deserialization.
- ClientIOSummary(ClientIOParameters, BaseParameters, Map<String, ClientIOTaskResult>, Map<Integer, Float>) - Constructor for class alluxio.stress.client.ClientIOSummary
-
Creates an instance.
- ClientIOSummary.GraphGenerator - Class in alluxio.stress.client
-
The graph generator for this summary.
- ClientIOTaskResult - Class in alluxio.stress.client
-
The task result for the master stress tests.
- ClientIOTaskResult() - Constructor for class alluxio.stress.client.ClientIOTaskResult
-
Creates an instance.
- ClientIOTaskResult.GraphGenerator - Class in alluxio.stress.client
-
The graph generator for this summary.
- ClientIOTaskResult.ThreadCountResult - Class in alluxio.stress.client
-
A result for a single thread count test.
- ClientMasterSync - Class in alluxio.client.metrics
-
Task that carries the client metrics information to master through heartheat.
- ClientMasterSync(String, ClientContext, MasterInquireClient) - Constructor for class alluxio.client.metrics.ClientMasterSync
-
- ClientMetrics - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.ClientMetrics
- ClientMetrics.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.ClientMetrics
- CLIENTMETRICS_FIELD_NUMBER - Static variable in class alluxio.grpc.MetricsHeartbeatPOptions
-
- ClientMetricsOrBuilder - Interface in alluxio.grpc
-
- clientOpened(BlockClient, BlockStoreLocation) - Method in interface alluxio.worker.block.io.BlockClientListener
-
Called when a new block client is opened.
- ClientPool - Class in alluxio.master
-
Keeps a collection of all clients (
FileSystem
) returned.
- ClientPoolKey(SocketAddress, String) - Constructor for class alluxio.client.file.FileSystemContext.ClientPoolKey
-
- ClientRWLock - Class in alluxio.concurrent
-
Read/write lock associated with clients rather than threads.
- ClientRWLock(int) - Constructor for class alluxio.concurrent.ClientRWLock
-
- Clients - Class in alluxio.multi.process
-
Container for various Alluxio clients.
- Clients(FileSystem, FileSystemMasterClient, MetaMasterClient, BlockMasterClient) - Constructor for class alluxio.multi.process.Clients
-
- ClientVersionClientInjector - Class in alluxio.grpc
-
Client side interceptor that is used to set the request header for the client version.
- ClientVersionClientInjector() - Constructor for class alluxio.grpc.ClientVersionClientInjector
-
- ClockCuckooFilter<T> - Interface in alluxio.client.file.cache.cuckoofilter
-
This interface represents a clock cuckoo filter that supports Put/Get/Delete operations.
- ClockCuckooShadowCacheManager - Class in alluxio.client.file.cache
-
- ClockCuckooShadowCacheManager(AlluxioConfiguration) - Constructor for class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
Create a ClockCuckooShadowCacheManager.
- clone() - Method in class alluxio.grpc.ActionInfo.Builder
-
- clone() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
- clone() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
- clone() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
- clone() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- clone() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- clone() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- clone() - Method in class alluxio.grpc.BackupPOptions.Builder
-
- clone() - Method in class alluxio.grpc.BackupPRequest.Builder
-
- clone() - Method in class alluxio.grpc.BackupPStatus.Builder
-
- clone() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- clone() - Method in class alluxio.grpc.Block.Builder
-
- clone() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- clone() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- clone() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
- clone() - Method in class alluxio.grpc.BlockIdList.Builder
-
- clone() - Method in class alluxio.grpc.BlockInfo.Builder
-
- clone() - Method in class alluxio.grpc.BlockLocation.Builder
-
- clone() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- clone() - Method in class alluxio.grpc.BlockStatus.Builder
-
- clone() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
- clone() - Method in class alluxio.grpc.BuildVersion.Builder
-
- clone() - Method in class alluxio.grpc.CacheRequest.Builder
-
- clone() - Method in class alluxio.grpc.CacheResponse.Builder
-
- clone() - Method in class alluxio.grpc.CancelPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CancelPRequest.Builder
-
- clone() - Method in class alluxio.grpc.CancelPResponse.Builder
-
- clone() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- clone() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- clone() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- clone() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- clone() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- clone() - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- clone() - Method in class alluxio.grpc.CheckRequest.Builder
-
- clone() - Method in class alluxio.grpc.CheckResponse.Builder
-
- clone() - Method in class alluxio.grpc.Chunk.Builder
-
- clone() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- clone() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- clone() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- clone() - Method in class alluxio.grpc.ClientMetrics.Builder
-
- clone() - Method in class alluxio.grpc.CmdProgress.Builder
-
- clone() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
- clone() - Method in class alluxio.grpc.CmdSummary.Builder
-
- clone() - Method in class alluxio.grpc.Command.Builder
-
- clone() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
- clone() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
-
- clone() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
- clone() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
- clone() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
-
- clone() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- clone() - Method in class alluxio.grpc.ConfigProperties.Builder
-
- clone() - Method in class alluxio.grpc.ConfigProperty.Builder
-
- clone() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CopyRequest.Builder
-
- clone() - Method in class alluxio.grpc.CopyResponse.Builder
-
- clone() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
- clone() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
-
- clone() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- clone() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
- clone() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
- clone() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
- clone() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
-
- clone() - Method in class alluxio.grpc.DeletePOptions.Builder
-
- clone() - Method in class alluxio.grpc.DeletePRequest.Builder
-
- clone() - Method in class alluxio.grpc.DeletePResponse.Builder
-
- clone() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- clone() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- clone() - Method in class alluxio.grpc.ErrorInfo.Builder
-
- clone() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
- clone() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ExistsPResponse.Builder
-
- clone() - Method in class alluxio.grpc.File.Builder
-
- clone() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
- clone() - Method in class alluxio.grpc.FileFailure.Builder
-
- clone() - Method in class alluxio.grpc.FileInfo.Builder
-
- clone() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
- clone() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
- clone() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
- clone() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
- clone() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
- clone() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
- clone() - Method in class alluxio.grpc.FreePOptions.Builder
-
- clone() - Method in class alluxio.grpc.FreePRequest.Builder
-
- clone() - Method in class alluxio.grpc.FreePResponse.Builder
-
- clone() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
-
- clone() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
-
- clone() - Method in class alluxio.grpc.FsOpPId.Builder
-
- clone() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- clone() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- clone() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
Deprecated.
- clone() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
- clone() - Method in class alluxio.grpc.InconsistentProperties.Builder
-
- clone() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- clone() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
- clone() - Method in class alluxio.grpc.JobCommand.Builder
-
- clone() - Method in class alluxio.grpc.JobDescription.Builder
-
- clone() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
-
- clone() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
- clone() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
- clone() - Method in class alluxio.grpc.JobInfo.Builder
-
- clone() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
-
- clone() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
- clone() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
- clone() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
- clone() - Method in class alluxio.grpc.JobProgress.Builder
-
- clone() - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
- clone() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
- clone() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
- clone() - Method in class alluxio.grpc.JobUnused.Builder
-
- clone() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
- clone() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
- clone() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- clone() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
- clone() - Method in class alluxio.grpc.ListAllPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
- clone() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
-
- clone() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
- clone() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
-
- clone() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
- clone() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- clone() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
- clone() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
- clone() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
- clone() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
- clone() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
- clone() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
- clone() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
- clone() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
- clone() - Method in class alluxio.grpc.LoadRequest.Builder
-
- clone() - Method in class alluxio.grpc.LoadResponse.Builder
-
- clone() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
- clone() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
- clone() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
- clone() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
- clone() - Method in class alluxio.grpc.MasterInfo.Builder
-
- clone() - Method in class alluxio.grpc.MasterVersion.Builder
-
- clone() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
- clone() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
- clone() - Method in class alluxio.grpc.Metric.Builder
-
- clone() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
- clone() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
- clone() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
-
- clone() - Method in class alluxio.grpc.MetricValue.Builder
-
- clone() - Method in class alluxio.grpc.MountPointInfo.Builder
-
- clone() - Method in class alluxio.grpc.MountPOptions.Builder
-
- clone() - Method in class alluxio.grpc.MountPRequest.Builder
-
- clone() - Method in class alluxio.grpc.MountPResponse.Builder
-
- clone() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
- clone() - Method in class alluxio.grpc.MoveBlockResponse.Builder
-
- clone() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
- clone() - Method in class alluxio.grpc.MoveRequest.Builder
-
- clone() - Method in class alluxio.grpc.MoveResponse.Builder
-
- clone() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
- clone() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
-
- clone() - Method in class alluxio.grpc.NetAddress.Builder
-
- clone() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
-
- clone() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
- clone() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
-
- clone() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
- clone() - Method in class alluxio.grpc.PAcl.Builder
-
- clone() - Method in class alluxio.grpc.PAclEntry.Builder
-
- clone() - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
- clone() - Method in class alluxio.grpc.PersistFile.Builder
-
- clone() - Method in class alluxio.grpc.PMode.Builder
-
- clone() - Method in class alluxio.grpc.PolicyInfo.Builder
-
- clone() - Method in class alluxio.grpc.PolicyStatus.Builder
-
- clone() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
- clone() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
-
- clone() - Method in class alluxio.grpc.ProxyStatus.Builder
-
- clone() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
- clone() - Method in class alluxio.grpc.ReadRequest.Builder
-
- clone() - Method in class alluxio.grpc.ReadResponse.Builder
-
- clone() - Method in class alluxio.grpc.RegisterCommand.Builder
-
- clone() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
- clone() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
- clone() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
-
- clone() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
-
- clone() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
- clone() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
- clone() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
- clone() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
- clone() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
-
- clone() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
- clone() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- clone() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
-
- clone() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
- clone() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
-
- clone() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
- clone() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
-
- clone() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
-
- clone() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
- clone() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
-
- clone() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
-
- clone() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
- clone() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
-
- clone() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
-
- clone() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
- clone() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
-
- clone() - Method in class alluxio.grpc.RenamePOptions.Builder
-
- clone() - Method in class alluxio.grpc.RenamePRequest.Builder
-
- clone() - Method in class alluxio.grpc.RenamePResponse.Builder
-
- clone() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
-
- clone() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- clone() - Method in class alluxio.grpc.RetryInfo.Builder
-
- clone() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
- clone() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
- clone() - Method in class alluxio.grpc.Route.Builder
-
- clone() - Method in class alluxio.grpc.RouteFailure.Builder
-
- clone() - Method in class alluxio.grpc.RunPOptions.Builder
-
- clone() - Method in class alluxio.grpc.RunPRequest.Builder
-
- clone() - Method in class alluxio.grpc.RunPResponse.Builder
-
- clone() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
- clone() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
- clone() - Method in class alluxio.grpc.SaslMessage.Builder
-
- clone() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
- clone() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
- clone() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
-
- clone() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
- clone() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
- clone() - Method in class alluxio.grpc.SetAclPResponse.Builder
-
- clone() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- clone() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
- clone() - Method in class alluxio.grpc.SetAttributePResponse.Builder
-
- clone() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
-
- clone() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- clone() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
-
- clone() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
- clone() - Method in class alluxio.grpc.SnapshotData.Builder
-
- clone() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
- clone() - Method in class alluxio.grpc.StatusSummary.Builder
-
- clone() - Method in class alluxio.grpc.StopJobPRequest.Builder
-
- clone() - Method in class alluxio.grpc.StopJobPResponse.Builder
-
- clone() - Method in class alluxio.grpc.StorageList.Builder
-
- clone() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
- clone() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
- clone() - Method in class alluxio.grpc.SubmitOptions.Builder
-
- clone() - Method in class alluxio.grpc.SubmitRequest.Builder
-
- clone() - Method in class alluxio.grpc.SubmitResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
- clone() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
- clone() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
- clone() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- clone() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
- clone() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
- clone() - Method in class alluxio.grpc.table.Constraint.Builder
-
- clone() - Method in class alluxio.grpc.table.Database.Builder
-
- clone() - Method in class alluxio.grpc.table.Date.Builder
-
- clone() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
- clone() - Method in class alluxio.grpc.table.Decimal.Builder
-
- clone() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
- clone() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.Domain.Builder
-
- clone() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
- clone() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
- clone() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
- clone() - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- clone() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.Layout.Builder
-
- clone() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
- clone() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- clone() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
- clone() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- clone() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- clone() - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
- clone() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
- clone() - Method in class alluxio.grpc.table.Partition.Builder
-
- clone() - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
- clone() - Method in class alluxio.grpc.table.Range.Builder
-
- clone() - Method in class alluxio.grpc.table.RangeSet.Builder
-
- clone() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.Schema.Builder
-
- clone() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
- clone() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- clone() - Method in class alluxio.grpc.table.TableInfo.Builder
-
- clone() - Method in class alluxio.grpc.table.Transformation.Builder
-
- clone() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
- clone() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
- clone() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
- clone() - Method in class alluxio.grpc.table.Value.Builder
-
- clone() - Method in class alluxio.grpc.TierList.Builder
-
- clone() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
- clone() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
-
- clone() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- clone() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- clone() - Method in class alluxio.grpc.TransportMessage.Builder
-
- clone() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
- clone() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
-
- clone() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
- clone() - Method in class alluxio.grpc.UfsInfo.Builder
-
- clone() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
- clone() - Method in class alluxio.grpc.UfsStatus.Builder
-
- clone() - Method in class alluxio.grpc.UnmountPOptions.Builder
-
- clone() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
- clone() - Method in class alluxio.grpc.UnmountPResponse.Builder
-
- clone() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- clone() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- clone() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- clone() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- clone() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- clone() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- clone() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- clone() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- clone() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- clone() - Method in class alluxio.grpc.WorkerIdentity.Builder
-
- clone() - Method in class alluxio.grpc.WorkerInfo.Builder
-
- clone() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- clone() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
- clone() - Method in class alluxio.grpc.WriteOptions.Builder
-
- clone() - Method in class alluxio.grpc.WriteRequest.Builder
-
- clone() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
- clone() - Method in class alluxio.grpc.WriteResponse.Builder
-
- clone() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
- clone() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
- clone() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
- clone() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
- clone() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
- clone() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
- clone() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
- clone() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
- clone() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
- clone() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
- clone() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- clone() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
- clone() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
- clone() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
- clone() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
- cloneByteBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
-
- cloneByteBufferList(List<ByteBuffer>) - Static method in class alluxio.util.io.BufferUtils
-
- close() - Method in class alluxio.AbstractClient
-
Closes the connection with the remote permanently.
- close() - Method in class alluxio.cli.AbstractShell
-
- close() - Method in class alluxio.cli.bundler.CollectInfo
-
- close() - Method in interface alluxio.cli.Command
-
Used to close resources created by commands.
- close() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
-
- close() - Method in class alluxio.cli.fsadmin.command.Context
-
- close() - Method in class alluxio.client.block.stream.BlockWorkerDataReader
-
- close() - Method in class alluxio.client.block.stream.BlockWorkerDataReader.Factory
-
- close() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
-
- close() - Method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
-
- close() - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- close() - Method in class alluxio.client.block.stream.GrpcBlockingStream
-
Closes the outbound stream.
- close() - Method in class alluxio.client.block.stream.GrpcDataReader
-
- close() - Method in class alluxio.client.block.stream.GrpcDataReader.Factory
-
- close() - Method in class alluxio.client.block.stream.GrpcDataWriter
-
- close() - Method in class alluxio.client.block.stream.NettyDataReader
-
- close() - Method in class alluxio.client.block.stream.NettyDataReader.Factory
-
- close() - Method in class alluxio.client.block.stream.NettyDataWriter
-
- close() - Method in class alluxio.client.block.stream.SharedGrpcDataReader
-
- close() - Method in class alluxio.client.block.stream.SharedGrpcDataReader.Factory
-
- close() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- close() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
-
- close() - Method in class alluxio.client.file.cache.LocalCacheManager
-
- close() - Method in class alluxio.client.file.cache.LocalCachePositionReader
-
- close() - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- close() - Method in class alluxio.client.file.cache.store.LocalPageStore
-
- close() - Method in class alluxio.client.file.cache.store.MemoryPageStore
-
- close() - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
Close the page store dir.
- close() - Method in class alluxio.client.file.cache.TimeBoundPageStore
-
- close() - Method in class alluxio.client.file.ConfigHashSync
-
- close() - Method in class alluxio.client.file.DelegatingFileSystem
-
- close() - Method in class alluxio.client.file.dora.DoraCachePositionReader
-
- close() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
-
- close() - Method in class alluxio.client.file.DoraFileOutStream
-
- close() - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- close() - Method in class alluxio.client.file.FileSystemContext
-
Closes all the resources associated with the context.
- close() - Method in class alluxio.client.file.FileSystemContextReinitializer
-
Shuts down the heartbeat thread immediately.
- close() - Method in class alluxio.client.file.FileSystemContextReinitializer.ReinitAllowerResource
-
- close() - Method in class alluxio.client.file.FileSystemContextReinitializer.ReinitBlockerResource
-
- close() - Method in class alluxio.client.file.MetadataCachingFileSystem
-
- close() - Method in class alluxio.client.file.PositionReadFileInStream
-
- close() - Method in class alluxio.client.file.ufs.DoraOutStream
-
- close() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
Shuts down the FileSystem.
- close() - Method in class alluxio.client.file.ufs.UfsFileInStream
-
- close() - Method in class alluxio.client.file.ufs.UfsFileOutStream
-
- close() - Method in class alluxio.client.job.JobContext
-
Closes all the resources associated with the context.
- close() - Method in class alluxio.client.job.JobMasterClientPool
-
- close() - Method in class alluxio.client.metrics.ClientMasterSync
-
Close the metrics master client.
- close() - Method in class alluxio.CloseableSupplier
-
- close() - Method in class alluxio.collections.LockPool
-
- close() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- close() - Method in class alluxio.fuse.AlluxioFuseUtils.CloseableFuseFileInfo
-
Closes the underlying resources.
- close() - Method in class alluxio.fuse.CreateFileEntry
-
Closes the underlying open streams.
- close() - Method in class alluxio.fuse.file.FuseFileEntry
-
Closes the underlying open streams.
- close() - Method in class alluxio.fuse.file.FuseFileInOrOutStream
-
- close() - Method in class alluxio.fuse.file.FuseFileInStream
-
- close() - Method in class alluxio.fuse.file.FuseFileOutStream
-
- close() - Method in interface alluxio.fuse.file.FuseFileStream
-
Closes the stream and releases the lock.
- close() - Method in class alluxio.fuse.file.FusePositionReader
-
- close() - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
-
- close() - Method in class alluxio.fuse.meta.UpdateChecker
-
- close() - Method in class alluxio.fuse.OpenFileEntry
-
Closes the underlying open streams.
- close() - Method in interface alluxio.grpc.BufferRepository
-
Closes the repository and all its buffers.
- close() - Method in class alluxio.grpc.DataMessageMarshaller
-
- close() - Method in class alluxio.grpc.GrpcChannel
-
Releases the connection to the pool.
- close() - Method in class alluxio.hadoop.AbstractFileSystem
-
- close() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
-
- close() - Method in class alluxio.hadoop.AlluxioHdfsPositionReader
-
- close() - Method in class alluxio.hadoop.BaseHdfsFileInputStream
-
- close() - Method in class alluxio.hadoop.LocalCacheFileSystem
-
- close() - Method in interface alluxio.heartbeat.HeartbeatExecutor
-
Cleans up any resources used by the heartbeat executor.
- close() - Method in class alluxio.master.AbstractMaster
-
- close() - Method in interface alluxio.master.audit.AuditContext
-
- close() - Method in class alluxio.master.backup.AbstractBackupRole
-
- close() - Method in class alluxio.master.backup.BackupLeaderRole
-
- close() - Method in class alluxio.master.backup.BackupWorkerRole
-
- close() - Method in class alluxio.master.block.DefaultBlockMaster
-
- close() - Method in class alluxio.master.block.DefaultBlockMaster.LostWorkerDetectionHeartbeatExecutor
-
- close() - Method in class alluxio.master.block.DefaultBlockMaster.WorkerRegisterStreamGCExecutor
-
- close() - Method in class alluxio.master.block.WorkerRegisterContext
-
- close() - Method in class alluxio.master.ClientPool
-
- close() - Method in class alluxio.master.file.DefaultBlockDeletionContext
-
- close() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- close() - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
- close() - Method in class alluxio.master.file.meta.CompositeInodeLockList
-
- close() - Method in interface alluxio.master.file.meta.InodeLockList
-
Closes the lock list, releasing all locks.
- close() - Method in class alluxio.master.file.meta.InodeLockManager
-
- close() - Method in class alluxio.master.file.meta.InodePathPair
-
- close() - Method in class alluxio.master.file.meta.InodeTree
-
Close resources associated with this tree instance.
- close() - Method in class alluxio.master.file.meta.InodeTreeBufferedIterator
-
- close() - Method in class alluxio.master.file.meta.LockedInodePath
-
- close() - Method in class alluxio.master.file.meta.LockedInodePathList
-
- close() - Method in class alluxio.master.file.meta.SimpleInodeLockList
-
- close() - Method in class alluxio.master.file.MetadataSyncLockManager.MetadataSyncPathList
-
- close() - Method in class alluxio.master.file.NoopBlockDeletionContext
-
- close() - Method in class alluxio.master.file.RpcContext
-
- close() - Method in class alluxio.master.job.JobMasterAuditContext
-
- close() - Method in class alluxio.master.journal.AsyncJournalWriter
-
Closes the async writer.
- close() - Method in class alluxio.master.journal.checkpoint.OptimizedCheckpointOutputStream
-
- close() - Method in class alluxio.master.journal.FileSystemMergeJournalContext
-
- close() - Method in interface alluxio.master.journal.JournalContext
-
- close() - Method in class alluxio.master.journal.JournalEntryStreamReader
-
- close() - Method in class alluxio.master.journal.MasterJournalContext
-
- close() - Method in class alluxio.master.journal.MergeJournalContext
-
- close() - Method in class alluxio.master.journal.MetadataSyncMergeJournalContext
-
- close() - Method in class alluxio.master.journal.noop.NoopJournal
-
- close() - Method in class alluxio.master.journal.NoopJournalContext
-
- close() - Method in class alluxio.master.journal.raft.BufferedJournalApplier
-
Resets the suspend-applier.
- close() - Method in class alluxio.master.journal.raft.JournalStateMachine
-
- close() - Method in class alluxio.master.journal.raft.RaftJournal
-
- close() - Method in class alluxio.master.journal.raft.RaftJournalAppender
-
- close() - Method in class alluxio.master.journal.raft.RaftJournalWriter
-
- close() - Method in class alluxio.master.journal.raft.RaftSnapshotManager
-
- close() - Method in class alluxio.master.journal.StateChangeJournalContext
-
- close() - Method in class alluxio.master.journal.ufs.UfsJournal
-
- close() - Method in class alluxio.master.journal.ufs.UfsJournalFileParser
-
- close() - Method in class alluxio.master.journal.ufs.UfsJournalLogWriter
-
- close() - Method in class alluxio.master.journal.ufs.UfsJournalReader
-
- close() - Method in interface alluxio.master.journalv0.JournalInputStream
-
Closes the stream.
- close() - Method in interface alluxio.master.journalv0.JournalOutputStream
-
Closes the stream.
- close() - Method in interface alluxio.master.journalv0.JournalWriter
-
Closes the journal.
- close() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
-
- close() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter.EntryOutputStream
-
- close() - Method in class alluxio.master.meta.JobMasterSync
-
- close() - Method in class alluxio.master.meta.JournalSpaceMonitor
-
- close() - Method in class alluxio.master.meta.MetaMasterSync
-
- close() - Method in class alluxio.master.meta.UpdateChecker
-
- close() - Method in interface alluxio.master.metastore.BlockMetaStore
-
Closes the block store and releases all resources.
- close() - Method in class alluxio.master.metastore.caching.Cache
-
- close() - Method in class alluxio.master.metastore.caching.CachingInodeStore
-
- close() - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- close() - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
-
- close() - Method in interface alluxio.master.metastore.InodeStore
-
- close() - Method in interface alluxio.master.metastore.InodeStore.WriteBatch
-
- close() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
-
- close() - Method in class alluxio.master.metastore.rocks.RocksExclusiveLockHandle
-
- close() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- close() - Method in class alluxio.master.metastore.rocks.RocksSharedLockHandle
-
- close() - Method in class alluxio.master.NoopMaster
-
- close() - Method in class alluxio.master.transport.GrpcMessagingClient
-
Closes the client.
- close() - Method in class alluxio.master.transport.GrpcMessagingClientConnection
-
- close() - Method in class alluxio.master.transport.GrpcMessagingConnection
-
Closes the connection.
- close() - Method in class alluxio.master.transport.GrpcMessagingContext
-
Closes the context.
- close() - Method in class alluxio.master.transport.GrpcMessagingServer
-
Closes the connection to the server if exists.
- close() - Method in class alluxio.master.transport.GrpcMessagingTransport
-
Closes the opened clients and servers.
- close() - Method in interface alluxio.master.transport.Listener
-
Closes the listener.
- close() - Method in class alluxio.master.transport.Listeners.ListenerHolder
-
- close() - Method in class alluxio.master.ZkMasterInquireClient
-
- close() - Method in class alluxio.membership.DefaultServiceEntity
-
- close() - Method in class alluxio.membership.EtcdMembershipManager
-
- close() - Method in class alluxio.membership.MasterMembershipManager
-
- close() - Method in class alluxio.membership.ServiceDiscoveryRecipe
-
- close() - Method in class alluxio.membership.StaticMembershipManager
-
- close() - Method in class alluxio.metrics.MetricsSystem.MultiTimerContext
-
Updates the timer with the difference between current and start time.
- close() - Method in class alluxio.multi.process.BaseMaster
-
- close() - Method in class alluxio.multi.process.Worker
-
- close() - Method in interface alluxio.PositionReader
-
Closes the positon reader and do cleanup job if any.
- close() - Method in class alluxio.proxy.ProxyMasterSync
-
- close() - Method in class alluxio.proxy.s3.RangeFileInStream
-
- close() - Method in class alluxio.proxy.s3.RateLimitInputStream
-
- CLOSE - Static variable in class alluxio.proxy.StreamsRestServiceHandler
-
- close(Integer) - Method in class alluxio.proxy.StreamsRestServiceHandler
-
- close() - Method in class alluxio.Registry
-
Closes all
Server
s in reverse dependency order.
- close() - Method in class alluxio.resource.CloseableResource
-
- close() - Method in class alluxio.resource.DynamicResourcePool
-
Closes the pool and clears all the resources.
- close() - Method in class alluxio.resource.LockResource
-
Releases the lock.
- close() - Method in class alluxio.resource.NoopCloseable
-
- close() - Method in class alluxio.resource.RefCountLockResource
-
Releases the lock and decrement the ref count if a ref counter was provided
at construction time.
- close() - Method in class alluxio.resource.ResourcePool
-
Closes the resource pool.
- close() - Method in class alluxio.rocks.RocksStore
-
- close() - Method in class alluxio.s3.S3AuditContext
-
- close() - Method in class alluxio.security.authentication.AbstractSaslClientHandler
-
- close() - Method in class alluxio.security.authentication.AbstractSaslServerHandler
-
- close() - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
-
Stops authenticated session with the server by releasing the long poll.
- close() - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
-
Completes authenticated channel.
- close() - Method in interface alluxio.security.authentication.AuthenticationServer
-
Closes the server, releases all authentication sessions.
- close() - Method in class alluxio.security.authentication.DefaultAuthenticationServer
-
- close() - Method in interface alluxio.security.authentication.SaslClientHandler
-
Close the handler and dispose internal resources.
- close() - Method in interface alluxio.security.authentication.SaslServerHandler
-
Close the handler and dispose internal resources.
- close() - Method in interface alluxio.Server
-
Closes the server.
- close() - Method in class alluxio.underfs.AbstractUfsManager
-
- close() - Method in class alluxio.underfs.AtomicFileOutputStream
-
- close() - Method in class alluxio.underfs.BaseUnderFileSystem
-
- close() - Method in class alluxio.underfs.ByteBufferResourcePool
-
- close() - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- close() - Method in class alluxio.underfs.cephfs.CephInputStream
-
- close() - Method in class alluxio.underfs.cephfs.CephOutputStream
-
- close() - Method in class alluxio.underfs.cos.COSOutputStream
-
Closes this output stream.
- close() - Method in class alluxio.underfs.gcs.GCSInputStream
-
- close() - Method in class alluxio.underfs.gcs.GCSOutputStream
-
- close() - Method in class alluxio.underfs.gcs.v2.GCSV2InputStream
-
- close() - Method in class alluxio.underfs.gcs.v2.GCSV2OutputStream
-
- close() - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
-
- close() - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
-
- close() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- close() - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- close() - Method in class alluxio.underfs.MultiRangeObjectInputStream
-
- close() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
-
- close() - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
-
- close() - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- close() - Method in class alluxio.underfs.obs.OBSOutputStream
-
Closes this output stream.
- close() - Method in class alluxio.underfs.oss.OSSOutputStream
-
Closes this output stream.
- close() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- close() - Method in class alluxio.underfs.oss.StsOssClientProvider
-
- close() - Method in class alluxio.underfs.s3a.S3AOutputStream
-
- close() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- close() - Method in class alluxio.underfs.UfsIOManager
-
Close.
- close() - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- close() - Method in interface alluxio.util.interfaces.Scoped
-
- close() - Method in class alluxio.worker.AbstractWorker
-
- close() - Method in class alluxio.worker.block.BlockMasterClientPool
-
- close() - Method in class alluxio.worker.block.io.BlockClient
-
- close() - Method in class alluxio.worker.block.io.BlockReadableChannel
-
- close() - Method in class alluxio.worker.dora.DoraMetaManager
-
- close() - Method in interface alluxio.worker.dora.DoraMetaStore
-
Closes the block store and releases all resources.
- close() - Method in class alluxio.worker.dora.OpenFileHandle
-
Close this handle.
- close() - Method in class alluxio.worker.dora.PagedDoraWorker
-
- close() - Method in class alluxio.worker.dora.PagedFileReader
-
- close() - Method in class alluxio.worker.dora.RocksDBDoraMetaStore
-
Closes the RocksDb and all resources.
- close() - Method in class alluxio.worker.grpc.GrpcDataServer
-
- close() - Method in class alluxio.worker.job.command.CommandHandlingExecutor
-
- close() - Method in class alluxio.worker.netty.FileReadHandler.FilePacketReader
-
- close() - Method in class alluxio.worker.netty.NettyDataServer
-
- close() - Method in class alluxio.worker.SessionCleaner
-
Stops the checking, once this method is called, the object should be discarded.
- CLOSE_ALLUXIO_OUTSTREAM_LATENCY - Static variable in class alluxio.metrics.MetricKey
-
- CLOSE_UFS_OUTSTREAM_LATENCY - Static variable in class alluxio.metrics.MetricKey
-
- CloseableFuseFileInfo() - Constructor for class alluxio.fuse.AlluxioFuseUtils.CloseableFuseFileInfo
-
Constructor.
- CloseableIterator<T> - Class in alluxio.resource
-
A CloseableIterator<T>
is an iterator which requires cleanup when it is no longer in use.
- CloseableIterator(Iterator<T>) - Constructor for class alluxio.resource.CloseableIterator
-
- CloseableResource<T> - Class in alluxio.resource
-
A CloseableResource<T>
is a wrapper around a resource of type T
which must do
some sort of cleanup when it is no longer in use.
- CloseableResource(T) - Constructor for class alluxio.resource.CloseableResource
-
- CloseableSupplier<T extends Closeable> - Class in alluxio
-
Closeable supplier which supports lazy initialization and cleanup if initialized.
- CloseableSupplier(Supplier<T>) - Constructor for class alluxio.CloseableSupplier
-
- closeAndRethrow(Closer, Throwable) - Static method in class alluxio.util.CommonUtils
-
Closes the Closer and re-throws the Throwable.
- closeAndRethrowRuntimeException(Closer, Throwable) - Static method in class alluxio.util.CommonUtils
-
- closeChannel(Channel) - Static method in class alluxio.util.CommonUtils
-
Closes the netty channel from outside the netty I/O thread.
- CLOSED_FS_ERROR_MESSAGE - Static variable in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- closeResource(BlockMasterClient) - Method in class alluxio.client.block.BlockMasterClientPool
-
- closeResource(BlockWorkerClient) - Method in class alluxio.client.block.stream.BlockWorkerClientPool
-
- closeResource(FileSystemMasterClient) - Method in class alluxio.client.file.FileSystemMasterClientPool
-
- closeResource(Channel) - Method in class alluxio.network.netty.NettyChannelPool
-
- closeResource() - Method in class alluxio.resource.CloseableResource
-
Performs any cleanup operations necessary when the resource is no longer in use.
- closeResource(T) - Method in class alluxio.resource.DynamicResourcePool
-
Closes the resource.
- closeResource() - Method in class alluxio.resource.PooledResource
-
- closeResource() - Method in class alluxio.worker.block.BlockLock
-
- closeStream() - Method in class alluxio.fuse.file.FuseFileInOrOutStream
-
- closeStream() - Method in class alluxio.fuse.file.FuseFileInStream
-
- closeStream() - Method in class alluxio.fuse.file.FuseFileOutStream
-
- closeStream() - Method in interface alluxio.fuse.file.FuseFileStream
-
Closes the stream without releasing the locking resource.
- closeStream() - Method in class alluxio.fuse.file.FusePositionReader
-
- closeStream() - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
-
- closeUfsBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
-
Closes a UFS block for a client session.
- CloudCostUtils - Class in alluxio.master.metrics
-
This class contains utilities to compute cloud cost savings.
- CLUSTER - Static variable in class alluxio.metrics.MetricsSystem
-
- CLUSTER_ACTIVE_RPC_READ_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_ACTIVE_RPC_WRITE_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_DIRECT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_DIRECT_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_DOMAIN - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_REMOTE - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_UFS - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_UFS_ALL - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_DOMAIN - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_REMOTE - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_UFS_ALL - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_CACHE_HIT_RATE - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_DEFAULT - Static variable in class alluxio.conf.Source
-
- CLUSTER_FLAG - Static variable in class alluxio.stress.BaseParameters
-
- CLUSTER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
- CLUSTER_ID_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
-
CLUSTER_ID = 10;
- CLUSTER_INFO_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
-
- CLUSTER_LEADER_ID - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_LEADER_INDEX - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_LIMIT_FLAG - Static variable in class alluxio.stress.BaseParameters
-
- CLUSTER_LOST_WORKERS - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_ROOT_UFS_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_ROOT_UFS_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_ROOT_UFS_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_START_DELAY_FLAG - Static variable in class alluxio.stress.BaseParameters
-
- CLUSTER_WORKERS - Static variable in class alluxio.metrics.MetricKey
-
- ClusterConfConsistencyValidationTask - Class in alluxio.cli
-
Task for validating Alluxio configuration consistency in the cluster.
- ClusterConfConsistencyValidationTask(AlluxioConfiguration) - Constructor for class alluxio.cli.ClusterConfConsistencyValidationTask
-
- CLUSTERCONFIGHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigHashPResponse
-
- CLUSTERCONFIGHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
-
- CLUSTERCONFIGLASTUPDATETIME_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
-
- CLUSTERCONFIGS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
-
- ClusterCounterKey(MetricsSystem.InstanceType, String) - Constructor for class alluxio.master.metrics.MetricsStore.ClusterCounterKey
-
- clusterDefaultsLoaded() - Method in interface alluxio.conf.AlluxioConfiguration
-
- clusterDefaultsLoaded() - Method in class alluxio.conf.InstancedConfiguration
-
- clusterDefaultsLoaded() - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- CLUSTERID_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
-
- CmdConfig - Interface in alluxio.job
-
A Cmd configuration.
- CMDCONFIG_FIELD_NUMBER - Static variable in class alluxio.grpc.SubmitRequest
-
- CmdInfo - Class in alluxio.master.job.common
-
A class representation for Command Information.
- CmdInfo(long, OperationType, JobSource, long, List<String>) - Constructor for class alluxio.master.job.common.CmdInfo
-
Constructor for CmdInfo class.
- CmdJobTracker - Class in alluxio.master.job.tracker
-
CmdJobTracker to schedule a Cmd job to run.
- CmdJobTracker(FileSystemContext, JobMaster) - Constructor for class alluxio.master.job.tracker.CmdJobTracker
-
- CmdJobTracker(FileSystemContext, MigrateCliRunner, PersistRunner) - Constructor for class alluxio.master.job.tracker.CmdJobTracker
-
Constructor with runner providers.
- CmdProgress - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CmdProgress
- CmdProgress.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CmdProgress
- CMDPROGRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
-
- CmdProgressOrBuilder - Interface in alluxio.grpc
-
- CmdRunAttempt - Class in alluxio.master.job.tracker
-
class for handling submission for a child job within a distributed command.
- CmdRunAttempt(RetryPolicy, JobMaster) - Constructor for class alluxio.master.job.tracker.CmdRunAttempt
-
- CMDSTATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetCmdStatusResponse
-
- CmdStatusBlock - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CmdStatusBlock
- CmdStatusBlock - Class in alluxio.job.wire
-
This class holds command status detailed information.
- CmdStatusBlock(long, OperationType) - Constructor for class alluxio.job.wire.CmdStatusBlock
-
Constructor.
- CmdStatusBlock(long, List<SimpleJobStatusBlock>, OperationType) - Constructor for class alluxio.job.wire.CmdStatusBlock
-
Constructor.
- CmdStatusBlock.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CmdStatusBlock
- CMDSTATUSBLOCK_FIELD_NUMBER - Static variable in class alluxio.grpc.GetCmdStatusDetailedResponse
-
- CmdStatusBlockOrBuilder - Interface in alluxio.grpc
-
- CmdSummary - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CmdSummary
- CmdSummary.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.CmdSummary
- CmdSummaryOrBuilder - Interface in alluxio.grpc
-
- CODE_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockStatus
-
- CODE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileFailure
-
- CODE_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileFailure
-
- CODE_FIELD_NUMBER - Static variable in class alluxio.grpc.RouteFailure
-
- COL_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsInfo
-
- COL_NAMES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
- COL_NAMES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
- COL_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsInfo
-
- collect(String[]) - Method in class alluxio.cli.bundler.CollectInfo
-
Execute the shell and generate a tarball.
- COLLECT_ON_EXIT - Static variable in class alluxio.ProcessUtils
-
- collectAllFutures(List<CompletableFuture<T>>) - Static method in class alluxio.cli.bundler.CollectInfo
-
Waits for ALL futures to complete and returns a list of results.
- CollectAlluxioInfoCommand - Class in alluxio.cli.bundler.command
-
Command to run a set of Alluxio commands.
- CollectAlluxioInfoCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
-
- CollectAlluxioInfoCommand.AlluxioCommand - Class in alluxio.cli.bundler.command
-
A special shell command that runs an Alluxio cmdline operation.
- CollectConfigCommand - Class in alluxio.cli.bundler.command
-
Command to collect Alluxio config files.
- CollectConfigCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectConfigCommand
-
- CollectEnvCommand - Class in alluxio.cli.bundler.command
-
Command to run a set of bash commands to get system information.
- CollectEnvCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectEnvCommand
-
- collectErrorsFromAllNodes() - Method in class alluxio.stress.common.GeneralBenchSummary
-
- CollectInfo - Class in alluxio.cli.bundler
-
Class for collecting various information about all nodes in the cluster.
- CollectInfo(AlluxioConfiguration) - Constructor for class alluxio.cli.bundler.CollectInfo
-
- CollectJvmInfoCommand - Class in alluxio.cli.bundler.command
-
Command that collects information about the JVMs.
- CollectJvmInfoCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectJvmInfoCommand
-
- CollectLogCommand - Class in alluxio.cli.bundler.command
-
Command to collect Alluxio logs.
- CollectLogCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectLogCommand
-
- CollectMetricsCommand - Class in alluxio.cli.bundler.command
-
Command to probe Alluxio metrics for a few times.
- CollectMetricsCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectMetricsCommand
-
- COLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Schema
-
- COLUMN_CONSTRAINTS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Constraint
-
- COLUMN_FIELD_NUMBER - Static variable in class alluxio.grpc.table.FileStatistics
-
- COLUMN_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.SortingColumn
-
- ColumnStatisticsData - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.ColumnStatisticsData
- ColumnStatisticsData.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.ColumnStatisticsData
- ColumnStatisticsData.DataCase - Enum in alluxio.grpc.table
-
- ColumnStatisticsDataOrBuilder - Interface in alluxio.grpc.table
-
- ColumnStatisticsInfo - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.ColumnStatisticsInfo
- ColumnStatisticsInfo.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.ColumnStatisticsInfo
- ColumnStatisticsInfoOrBuilder - Interface in alluxio.grpc.table
-
- ColumnStatisticsList - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.ColumnStatisticsList
- ColumnStatisticsList.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.ColumnStatisticsList
- ColumnStatisticsListOrBuilder - Interface in alluxio.grpc.table
-
- combine(Scope, Scope) - Static method in class alluxio.grpc.GrpcUtils
-
- combineData(DataMessage<T, DataBuffer>) - Method in class alluxio.grpc.DataMessageMarshaller
-
Combines the data buffer into the message.
- combineData(DataMessage<ReadResponse, DataBuffer>) - Method in class alluxio.grpc.ReadResponseMarshaller
-
- combineData(DataMessage<WriteRequest, DataBuffer>) - Method in class alluxio.grpc.WriteRequestMarshaller
-
- Command - Interface in alluxio.cli
-
An interface for all the commands that can be run from a shell.
- Command - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.Command
- Command.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.Command
- COMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPResponse
-
- COMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemHeartbeatPResponse
-
- COMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.JobMasterHeartbeatPResponse
-
- COMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterHeartbeatPResponse
-
- COMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequest
-
- COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
-
- COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectConfigCommand
-
- COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectEnvCommand
-
- COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectJvmInfoCommand
-
- COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectLogCommand
-
- COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectMetricsCommand
-
- CommandHandlingExecutor - Class in alluxio.worker.job.command
-
Manages the communication with the master.
- CommandHandlingExecutor(JobServerContext, TaskExecutorManager, JobMasterClient, WorkerNetAddress) - Constructor for class alluxio.worker.job.command.CommandHandlingExecutor
-
- CommandManager - Class in alluxio.master.job.command
-
A command manager that manages the commands to issue to the workers.
- CommandManager() - Constructor for class alluxio.master.job.command.CommandManager
-
- COMMANDOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemCommand
-
- CommandOrBuilder - Interface in alluxio.grpc
-
- CommandReturn - Class in alluxio.shell
-
Object representation of a command execution.
- CommandReturn(int, String) - Constructor for class alluxio.shell.CommandReturn
-
Creates object from the contents.
- CommandReturn(int, String[], String) - Constructor for class alluxio.shell.CommandReturn
-
Creates object from the contents.
- COMMANDS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobHeartbeatPResponse
-
- CommandType - Enum in alluxio.grpc
-
Protobuf enum alluxio.grpc.CommandType
- CommandType - Enum in alluxio.wire
-
Types for file system commands.
- COMMANDTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.Command
-
- COMMANDTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemCommand
-
- CommandUtils - Class in alluxio.cli
-
Class for convenience methods used by instances of
Command
.
- COMMENT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
-
- COMMENT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.FieldSchema
-
- commit(String) - Method in interface alluxio.client.file.cache.PageStore
-
Commit a temporary file.
- commit(String, String) - Method in interface alluxio.client.file.cache.PageStore
-
Commit a temporary file with a new file ID.
- commit(String, String) - Method in class alluxio.client.file.cache.store.LocalPageStore
-
- commit(String) - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
Commit a temporary file.
- commit(String, String) - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
Commit a temporary file with a new file ID.
- commit() - Method in interface alluxio.master.metastore.InodeStore.WriteBatch
-
Performs the batched write.
- commit() - Method in class alluxio.security.login.AlluxioLoginModule
-
Commits the authentication (second phase).
- commit() - Method in class alluxio.security.login.AppLoginModule
-
Commits the authentication (second phase).
- commitBlock(CommitBlockPRequest, StreamObserver<CommitBlockPResponse>) - Method in interface alluxio.grpc.BlockMasterWorkerServiceGrpc.AsyncService
-
Marks the given block as committed.
- commitBlock(CommitBlockPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub
-
Marks the given block as committed.
- commitBlock(CommitBlockPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub
-
Marks the given block as committed.
- commitBlock(CommitBlockPRequest, StreamObserver<CommitBlockPResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
-
Marks the given block as committed.
- commitBlock(long, long, String, String, long, long) - Method in interface alluxio.master.block.BlockMaster
-
Marks a block as committed on a specific worker.
- commitBlock(CommitBlockPRequest, StreamObserver<CommitBlockPResponse>) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
-
- commitBlock(long, long, String, String, long, long) - Method in class alluxio.master.block.DefaultBlockMaster
-
- commitBlock(long, long, String, String, long, long) - Method in class alluxio.worker.block.BlockMasterClient
-
Commits a block on a worker.
- commitBlock(long, long, boolean) - Method in interface alluxio.worker.block.BlockStore
-
Commits a block to Alluxio managed space.
- commitBlock(long, long, boolean) - Method in interface alluxio.worker.block.BlockWorker
-
Commits a block to Alluxio managed space.
- commitBlockInUFS(long, long) - Method in interface alluxio.master.block.BlockMaster
-
Marks a block as committed, but without a worker location.
- commitBlockInUFS(long, long, JournalContext) - Method in interface alluxio.master.block.BlockMaster
-
Marks a block as committed, but without a worker location.
- commitBlockInUFS(long, long, JournalContext) - Method in class alluxio.master.block.DefaultBlockMaster
-
- CommitBlockPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.CommitBlockPOptions
- CommitBlockPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.CommitBlockPOptions
- CommitBlockPOptionsOrBuilder - Interface in alluxio.grpc
-
- CommitBlockPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.CommitBlockPRequest
- CommitBlockPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.CommitBlockPRequest
- CommitBlockPRequestOrBuilder - Interface in alluxio.grpc
-
- CommitBlockPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.CommitBlockPResponse
- CommitBlockPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.CommitBlockPResponse
- CommitBlockPResponseOrBuilder - Interface in alluxio.grpc
-
- commitFile(String) - Method in interface alluxio.client.file.cache.CacheManager
-
Commit the File.
- commitFile(String) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- commitFile(String, String) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
-
- commitFile(String) - Method in class alluxio.client.file.cache.LocalCacheManager
-
- commitFile(String) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- commitFile(String, String) - Method in interface alluxio.client.file.cache.PageMetaStore
-
Commits a temp file so that all its pages become permanent.
- commitFile() - Method in class alluxio.worker.block.io.BlockWriter
-
Commit the file.
- commitFile() - Method in class alluxio.worker.dora.PagedFileWriter
-
- COMMON_SSH_OPTS - Static variable in class alluxio.util.ShellUtils
-
Common shell OPTS to prevent stalling.
- commonDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- commonDefaults(AlluxioConfiguration, boolean) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckAccessPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckConsistencyPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CompleteFilePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ExistsPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FreePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStatusPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadMetadataPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenFilePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAclPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.UnmountPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
- commonPool() - Static method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns the common pool instance.
- CommonProto - Class in alluxio.grpc
-
- CommonUtils - Class in alluxio.util
-
Common utilities shared by all components in Alluxio.
- CommonUtils.ProcessType - Enum in alluxio.util
-
Alluxio process types.
- compare(URIStatus, URIStatus) - Method in class alluxio.proxy.s3.S3RestUtils.URIStatusNameComparator
-
- compare(String, String) - Static method in class alluxio.util.URIUtils
-
- compare(WorkerInfo, WorkerInfo) - Method in class alluxio.wire.WorkerInfo.LastContactSecComparator
-
- COMPARE_CHECK_FILES - Static variable in class alluxio.cli.fs.command.ConsistentHashCommand
-
- compareAndSetForkJoinTaskTag(short, short) - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Atomically conditionally sets the tag value for this task.
- compareAndSetPendingCount(int, int) - Method in class alluxio.concurrent.jsr.CountedCompleter
-
Sets (atomically) the pending count to the given count only if it currently holds the given
expected value.
- compareAndSetServerConfigReference(InstancedConfiguration, InstancedConfiguration) - Static method in class alluxio.conf.Configuration
-
Compares and swap the two conf.
- compareTierNames(String, String) - Static method in class alluxio.cli.fsadmin.FileSystemAdminShellUtils
-
Compares two tier names according to their rank values.
- compareTo(AlluxioURI) - Method in class alluxio.AlluxioURI
-
- compareTo(PropertyKey) - Method in class alluxio.conf.PropertyKey
-
- compareTo(Source) - Method in class alluxio.conf.Source
-
- compareTo(PlanInfo) - Method in class alluxio.job.plan.meta.PlanInfo
-
This method orders jobs using the time their status was last modified.
- compareTo(Version) - Method in class alluxio.master.backcompat.Version
-
- compareTo(InodeView) - Method in interface alluxio.master.file.meta.InodeView
-
- compareTo(TtlBucket) - Method in class alluxio.master.file.meta.TtlBucket
-
Compares this bucket's TTL interval start time to that of another bucket.
- compareTo(Task) - Method in class alluxio.master.job.CopyJob.CopyTask
-
- compareTo(UfsJournalFile) - Method in class alluxio.master.journal.ufs.UfsJournalFile
-
- compareTo(Interval) - Method in class alluxio.master.predicate.interval.Interval
-
- compareTo(MetricKey) - Method in class alluxio.metrics.MetricKey
-
- compareTo(Task) - Method in class alluxio.scheduler.job.Task
-
- compareTo(Authority) - Method in interface alluxio.uri.Authority
-
- compareTo(Authority) - Method in class alluxio.uri.EmbeddedLogicalAuthority
-
- compareTo(Authority) - Method in class alluxio.uri.MultiMasterAuthority
-
- compareTo(URI) - Method in class alluxio.uri.StandardURI
-
- compareTo(Authority) - Method in class alluxio.uri.ZookeeperLogicalAuthority
-
- compareTo(NodeInfo) - Method in class alluxio.util.webui.NodeInfo
-
Compare
NodeInfo
by lexicographical order of their associated host.
- compareVersion(String, String) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Compares two version.
- CompletableFuture<T> - Class in alluxio.concurrent.jsr
-
A
Future
that may be explicitly completed (setting its value and status), and may be used
as a
CompletionStage
, supporting dependent functions and actions that trigger upon its
completion.
- CompletableFuture() - Constructor for class alluxio.concurrent.jsr.CompletableFuture
-
Creates a new incomplete CompletableFuture.
- CompletableFuture.AsynchronousCompletionTask - Interface in alluxio.concurrent.jsr
-
A marker interface identifying asynchronous tasks produced by async
methods.
- complete(T) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
If not already completed, sets the value returned by
CompletableFuture.get()
and related methods to the
given value.
- complete(T) - Method in class alluxio.concurrent.jsr.CountedCompleter
-
- complete(V) - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Completes this task, and if not already aborted or cancelled, returning the given value as the
result of subsequent invocations of join
and related operations.
- complete() - Method in class alluxio.master.file.ListStatusPartialResultStream
-
Called once the listing is complete, and sends the response to the client.
- complete() - Method in class alluxio.master.file.ListStatusResultStream
-
Used to complete the stream.
- complete() - Method in interface alluxio.underfs.MultipartUploader
-
Complete a multipart upload.
- COMPLETE_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
-
- completeAsync(Supplier<? extends T>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
Completes this CompletableFuture with the result of the given Supplier function invoked from an
asynchronous task using the given executor.
- completeAsync(Supplier<? extends T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
Completes this CompletableFuture with the result of the given Supplier function invoked from an
asynchronous task using the default executor.
- completeCurrentLog() - Method in interface alluxio.master.journalv0.JournalWriter
-
Marks the current log as completed.
- completeCurrentLog() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
-
- completed() - Static method in class alluxio.master.journal.CatchupFuture
-
- COMPLETED_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
-
- COMPLETED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
-
- COMPLETED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- Completed_VALUE - Static variable in enum alluxio.grpc.BackupState
-
Completed = 5;
- COMPLETED_VALUE - Static variable in enum alluxio.grpc.Status
-
COMPLETED = 5;
- completedFuture(U) - Static method in class alluxio.concurrent.jsr.CompletableFuture
-
Returns a new CompletableFuture that is already completed with the given value.
- completedStage(U) - Static method in class alluxio.concurrent.jsr.CompletableFuture
-
Returns a new CompletionStage that is already completed with the given value and supports only
those methods in interface
CompletionStage
.
- completeExceptionally(Throwable) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
If not already completed, causes invocations of
CompletableFuture.get()
and related methods to throw the
given exception.
- completeExceptionally(Throwable) - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Completes this task abnormally, and if not already aborted or cancelled, causes it to throw the
given exception upon join
and related operations.
- completeExceptionally(Exception) - Static method in class alluxio.master.journal.raft.RaftJournalUtils
-
Creates a future that is completed exceptionally.
- completeFile(CompleteFilePRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
-
Complete a file when writing is done.
- completeFile(CompleteFilePRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- completeFile(String, CompleteFilePOptions, String) - Method in class alluxio.client.file.dora.DoraCacheClient
-
Mark the newly created and written file as complete.
- completeFile(AlluxioURI, CompleteFilePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Marks a file as completed.
- completeFile(AlluxioURI, CompleteFilePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
-
Marks a file as completed.
- completeFile(CompleteFilePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
-
Marks a file as completed.
- completeFile(CompleteFilePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
-
Marks a file as completed.
- completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
-
Marks a file as completed.
- completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Marks a file as completed.
- completeFile(CompleteFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Marks a file as completed.
- completeFile(CompleteFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Marks a file as completed.
- completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Marks a file as completed.
- completeFile(AlluxioURI, CompleteFileContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- completeFile(AlluxioURI, CompleteFileContext) - Method in interface alluxio.master.file.FileSystemMaster
-
Completes a file.
- completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- completeFile(String, CompleteFilePOptions, String) - Method in interface alluxio.worker.dora.DoraWorker
-
Complete writing a file.
- completeFile(String, CompleteFilePOptions, String) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
-
- CompleteFileContext - Class in alluxio.master.file.contexts
-
- completeFileDefaults() - Static method in class alluxio.master.file.FileSystemMasterOptions
-
- CompleteFilePOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CompleteFilePOptions
- CompleteFilePOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CompleteFilePOptions
- CompleteFilePOptionsOrBuilder - Interface in alluxio.grpc
-
- CompleteFilePRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CompleteFilePRequest
- CompleteFilePRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CompleteFilePRequest
- CompleteFilePRequestOrBuilder - Interface in alluxio.grpc
-
- CompleteFilePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CompleteFilePResponse
- CompleteFilePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CompleteFilePResponse
- CompleteFilePResponseOrBuilder - Interface in alluxio.grpc
-
- completeLogs() - Method in interface alluxio.master.journalv0.JournalWriter
-
Marks all logs as completed.
- completeLogs() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
-
- CompleteMultipartUploadHandler - Class in alluxio.proxy.s3
-
A handler process multipart upload complete response.
- CompleteMultipartUploadHandler(FileSystem, String) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadHandler
-
- CompleteMultipartUploadHandler.CompleteMultipartUploadTask - Class in alluxio.proxy.s3
-
Complete Multipart upload Task.
- completeMultipartUploadInternal() - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
-
- completeMultiPartUploadInternal() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
-
- completeMultipartUploadInternal() - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
-
- completeMultiPartUploadInternal() - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
-
- completeMultipartUploadInternal() - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
-
- completeMultiPartUploadInternal() - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
-
- completeMultipartUploadInternal() - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
-
- completeMultiPartUploadInternal() - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
-
- completeMultipartUploadInternal() - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
-
- CompleteMultipartUploadRequest - Class in alluxio.proxy.s3
-
Implementation of CompleteMultipartUploadRequest according to
https://docs.aws.amazon.com/AmazonS3/latest/API/API_ListMultipartUploads.html.
- CompleteMultipartUploadRequest() - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadRequest
-
- CompleteMultipartUploadRequest(List<CompleteMultipartUploadRequest.Part>) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadRequest
-
- CompleteMultipartUploadRequest(List<CompleteMultipartUploadRequest.Part>, boolean) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadRequest
-
- CompleteMultipartUploadRequest.Part - Class in alluxio.proxy.s3
-
The Part POJO.
- CompleteMultipartUploadResult - Class in alluxio.proxy.s3
-
Result returned after requests for completing a multipart upload.
- CompleteMultipartUploadResult() - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- CompleteMultipartUploadResult(String, String, String, String) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- CompleteMultipartUploadResult(String, String) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- CompleteMultipartUploadTask(FileSystem, FileSystem, String, String, String, String) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
-
- CompleteMultipartUploadTask(S3Handler, S3BaseTask.OpType) - Constructor for class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
-
Create a CompleteMultipartUploadTask.
- completeOnTimeout(T, long, TimeUnit) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
Completes this CompletableFuture with the given value if not otherwise completed before the
given timeout.
- completeRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
-
- completeRequest(BlockWriteRequestContext, Channel) - Method in class alluxio.worker.netty.FileWriteHandler.BlockPacketWriter
-
- completeRequest(UfsFileWriteRequestContext, Channel) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
-
- CompletionStage<T> - Interface in alluxio.concurrent.jsr
-
A stage of a possibly asynchronous computation, that performs an action or computes a value when
another CompletionStage completes.
- CompositeConfig - Class in alluxio.job.workflow.composite
-
A composite job is a list of jobs to be executed either sequentially or concurrently.
- CompositeConfig(ArrayList<JobConfig>, Boolean) - Constructor for class alluxio.job.workflow.composite.CompositeConfig
-
- CompositeDataBuffer - Class in alluxio.network.protocol.databuffer
-
- CompositeDataBuffer(List<DataBuffer>) - Constructor for class alluxio.network.protocol.databuffer.CompositeDataBuffer
-
- CompositeExecution - Class in alluxio.job.workflow.composite
-
- CompositeExecution(CompositeConfig) - Constructor for class alluxio.job.workflow.composite.CompositeExecution
-
Default constructor.
- CompositeExecutionFactory - Class in alluxio.job.workflow.composite
-
- CompositeExecutionFactory() - Constructor for class alluxio.job.workflow.composite.CompositeExecutionFactory
-
- CompositeInodeLockList - Class in alluxio.master.file.meta
-
Manages the locks for a list of inodes, based off an existing lock list.
- CompositeInodeLockList(InodeLockList, boolean) - Constructor for class alluxio.master.file.meta.CompositeInodeLockList
-
Constructs a new lock list, using an existing lock list as the base list.
- CompoundCheckpointFormat - Class in alluxio.master.journal.checkpoint
-
Format for compound checkpoints.
- CompoundCheckpointFormat() - Constructor for class alluxio.master.journal.checkpoint.CompoundCheckpointFormat
-
- CompoundCheckpointFormat.CompoundCheckpointReader - Class in alluxio.master.journal.checkpoint
-
Reader for compound checkpoints.
- CompoundCheckpointFormat.CompoundCheckpointReader.Entry - Class in alluxio.master.journal.checkpoint
-
A compound checkpoint entry.
- CompoundCheckpointReader(CheckpointInputStream) - Constructor for class alluxio.master.journal.checkpoint.CompoundCheckpointFormat.CompoundCheckpointReader
-
- compress(String, File...) - Static method in class alluxio.cli.bundler.TarUtils
-
Compresses a list of files to one destination.
- compress(Path, OutputStream, int, int) - Static method in class alluxio.util.compression.ParallelZipUtils
-
Creates a zipped archive from the given path in parallel, streaming the data
to the give output stream.
- compute() - Method in class alluxio.concurrent.jsr.CountedCompleter
-
The main computation performed by this task.
- computeNextWaitTime() - Method in class alluxio.retry.ExponentialTimeBoundedRetry
-
- computeNextWaitTime() - Method in class alluxio.retry.TimeBoundedRetry
-
- computeSyncPlan(Inode, Fingerprint, boolean) - Static method in class alluxio.master.file.meta.UfsSyncUtils
-
Given an inode and ufs status, returns a sync plan describing how to
sync the inode with the ufs.
- computeTimeData() - Method in class alluxio.stress.common.SummaryStatistics
-
- concat(CloseableIterator<T>, CloseableIterator<T>) - Static method in class alluxio.resource.CloseableIterator
-
Combines two iterators into a single iterator.
- concat(List<CloseableIterator<T>>) - Static method in class alluxio.resource.CloseableIterator
-
Concatenates iterators.
- concatPath(Object, Object) - Static method in class alluxio.util.io.PathUtils
-
- concatPath(Object, Object...) - Static method in class alluxio.util.io.PathUtils
-
- concatUfsPath(String, String) - Static method in class alluxio.util.io.PathUtils
-
- ConcurrentClockCuckooFilter<T> - Class in alluxio.client.file.cache.cuckoofilter
-
A concurrent cuckoo filter with three customized field: clock, size and scope.
- ConcurrentHashSet<T> - Class in alluxio.collections
-
A concurrent hash set.
- ConcurrentHashSet() - Constructor for class alluxio.collections.ConcurrentHashSet
-
- ConcurrentHashSet(int, float, int) - Constructor for class alluxio.collections.ConcurrentHashSet
-
- ConcurrentIdentityHashMap<K,V> - Class in alluxio.collections
-
An implementation
ConcurrentHashMap
that utilizes identity semantics
with its keys
Having identity semantics means that it is possible to have two objects with which are
equal based on the object's
equals()
implementation, but not be overridden in the hash
map if you try to put both.
- ConcurrentIdentityHashMap() - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
-
Creates a new, empty map with the default initial table size (16).
- ConcurrentIdentityHashMap(int) - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
-
Creates a new, empty map with an initial table size accommodating the specified number of
elements without having to dynamically resize.
- ConcurrentIdentityHashMap(int, float) - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
-
Creates a new, empty map with an initial table size based on the given number of elements
(initialCapacity
) and initial load factor (loadFactor
) with a
concurrencyLevel
of 1.
- ConcurrentIdentityHashMap(int, float, int) - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
-
Creates a new, empty map with an initial table size based on the given number of elements
(initialCapacity
), load factor (loadFactor
), and number of
expected concurrently updating threads (concurrencyLevel
).
- concurrentReadPart() - Method in class alluxio.PositionReaderTest
-
Tests concurrently read from position reader.
- CONF - Static variable in class alluxio.stress.worker.UfsIOParameters
-
- CONF_DIR - Static variable in class alluxio.conf.PropertyKey
-
- CONF_DIR - Static variable in class alluxio.conf.PropertyKey.Name
-
- CONF_DYNAMIC_UPDATE_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- CONF_DYNAMIC_UPDATE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- CONF_REGEX - Static variable in class alluxio.conf.PropertyKey
-
Regex to find ${key} for variable substitution.
- CONF_VALIDATION_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- CONF_VALIDATION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- CONFIG_CHECKER_MULTI_MASTERS - Static variable in class alluxio.multi.process.PortCoordination
-
- CONFIG_CHECKER_MULTI_MASTERS_EMBEDDED_HA - Static variable in class alluxio.multi.process.PortCoordination
-
- CONFIG_CHECKER_MULTI_NODES - Static variable in class alluxio.multi.process.PortCoordination
-
- CONFIG_CHECKER_MULTI_WORKERS - Static variable in class alluxio.multi.process.PortCoordination
-
- CONFIG_CHECKER_UNSET_VS_SET - Static variable in class alluxio.multi.process.PortCoordination
-
- ConfigCheckReport - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.ConfigCheckReport
- ConfigCheckReport - Class in alluxio.wire
-
Represents a configuration report which records the configuration checker results.
- ConfigCheckReport() - Constructor for class alluxio.wire.ConfigCheckReport
-
- ConfigCheckReport(Map<Scope, List<InconsistentProperty>>, Map<Scope, List<InconsistentProperty>>, ConfigStatus) - Constructor for class alluxio.wire.ConfigCheckReport
-
- ConfigCheckReport(ConfigCheckReport) - Constructor for class alluxio.wire.ConfigCheckReport
-
- ConfigCheckReport.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.ConfigCheckReport
- ConfigCheckReportOrBuilder - Interface in alluxio.grpc
-
- ConfigHash - Class in alluxio.wire
-
Hashes of cluster and path level configurations.
- ConfigHash(String, String, long, long) - Constructor for class alluxio.wire.ConfigHash
-
Constructs a new ConfigHash.
- ConfigHashSync - Class in alluxio.client.file
-
Heartbeat task for getting the latest configuration versions from meta master, if versions
change, then re-initialize the filesystem context.
- ConfigHashSync(FileSystemContext) - Constructor for class alluxio.client.file.ConfigHashSync
-
- ConfigProperties - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.ConfigProperties
- ConfigProperties.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.ConfigProperties
- ConfigPropertiesOrBuilder - Interface in alluxio.grpc
-
- ConfigProperty - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.ConfigProperty
- ConfigProperty.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.ConfigProperty
- ConfigPropertyOrBuilder - Interface in alluxio.grpc
-
- ConfigRecord - Class in alluxio.master.meta.checkconf
-
An Alluxio configuration record.
- ConfigRecord() - Constructor for class alluxio.master.meta.checkconf.ConfigRecord
-
- ConfigRecord(PropertyKey, String, String) - Constructor for class alluxio.master.meta.checkconf.ConfigRecord
-
- CONFIGS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterMasterPOptions
-
- CONFIGS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPOptions
-
- ConfigStatus - Enum in alluxio.grpc
-
Protobuf enum alluxio.grpc.meta.ConfigStatus
- Configuration - Class in alluxio.conf
-
Global configuration properties of Alluxio.
- Configuration - Class in alluxio.wire
-
Represents cluster level and path level configuration returned by meta master.
- Configuration.Builder - Class in alluxio.wire
-
Configuration builder.
- ConfigurationChecker - Class in alluxio.master.meta.checkconf
-
This class is responsible for checking server-side configuration.
- ConfigurationChecker(ConfigurationStore, ConfigurationStore) - Constructor for class alluxio.master.meta.checkconf.ConfigurationChecker
-
- ConfigurationCommand - Class in alluxio.cli.fsadmin.doctor
-
Prints server-side configuration errors and warnings.
- ConfigurationCommand(MetaMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.doctor.ConfigurationCommand
-
- ConfigurationDocGenerator - Class in alluxio.cli.docgen
-
CSV_FILE_DIR utility to generate property keys to csv files.
- ConfigurationStore - Class in alluxio.master.meta.checkconf
-
This class is responsible for recording server-side configuration.
- ConfigurationStore() - Constructor for class alluxio.master.meta.checkconf.ConfigurationStore
-
- ConfigurationUtils - Class in alluxio.util
-
Utilities for working with Alluxio configurations.
- ConfigurationValueOptions - Class in alluxio.conf
-
Options for getting configuration values.
- configure() - Method in class alluxio.worker.modules.AlluxioWorkerProcessModule
-
- configure() - Method in class alluxio.worker.modules.DoraWorkerModule
-
- configure() - Method in class alluxio.worker.modules.GrpcServerModule
-
- configure() - Method in class alluxio.worker.modules.NettyServerModule
-
- connect() - Method in class alluxio.AbstractClient
-
Connects with the remote.
- connect() - Method in interface alluxio.Client
-
Connects with the remote.
- connect(StreamObserver<TransportMessage>) - Method in interface alluxio.grpc.MessagingServiceGrpc.AsyncService
-
- connect(StreamObserver<TransportMessage>) - Method in class alluxio.grpc.MessagingServiceGrpc.MessagingServiceStub
-
- connect() - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
-
- connect(InetSocketAddress) - Method in class alluxio.master.transport.GrpcMessagingClient
-
Creates a client and connects to the given address.
- connect(StreamObserver<TransportMessage>) - Method in class alluxio.master.transport.GrpcMessagingServiceClientHandler
-
RPC for establishing bi-di stream between client/server.
- connectFromMaster(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- connectFromMaster(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- connectFromMaster(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- connectFromMaster(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- connectFromMaster(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- connectFromMaster(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Takes any necessary actions required to establish a connection to the under file system from
the given master host e.g.
- connectFromMaster(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- connectFromWorker(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- connectFromWorker(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- connectFromWorker(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- connectFromWorker(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- connectFromWorker(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- connectFromWorker(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Takes any necessary actions required to establish a connection to the under file system from
the given worker host e.g.
- connectFromWorker(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- ConnectionFailedException - Exception in alluxio.exception
-
Exception used when a network connection failure occurs.
- ConnectionFailedException(String) - Constructor for exception alluxio.exception.ConnectionFailedException
-
Constructs a new exception with the specified detail message.
- ConnectionFailedException(String, Throwable) - Constructor for exception alluxio.exception.ConnectionFailedException
-
Constructs a new exception with the specified detail message and cause.
- ConnectionFailedException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.ConnectionFailedException
-
Constructs a new exception with the specified exception message and multiple parameters.
- ConnectionFailedException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.ConnectionFailedException
-
Constructs a new exception with the specified exception message, the cause and multiple
parameters.
- connectUfs(UnderFileSystem) - Method in class alluxio.master.NoopUfsManager
-
- connectUfs(UnderFileSystem) - Method in class alluxio.underfs.AbstractUfsManager
-
Takes any necessary actions required to establish a connection to the under file system.
- connectUfs(UnderFileSystem) - Method in class alluxio.underfs.JobUfsManager
-
- connectUfs(UnderFileSystem) - Method in class alluxio.underfs.MasterUfsManager
-
- connectUfs(UnderFileSystem) - Method in class alluxio.underfs.WorkerUfsManager
-
- connectUfs(UnderFileSystem) - Method in class alluxio.worker.dora.DoraUfsManager
-
- connectWithRuntimeException() - Method in class alluxio.AbstractClient
-
Connects with the remote server.
- ConsistentHashCommand - Class in alluxio.cli.fs.command
-
Copies the specified file specified by "source path" to the path specified by "remote path".
- ConsistentHashCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ConsistentHashCommand
-
- ConsistentHashPolicy - Class in alluxio.client.file.dora
-
An impl of WorkerLocationPolicy.
- ConsistentHashPolicy(AlluxioConfiguration) - Constructor for class alluxio.client.file.dora.ConsistentHashPolicy
-
- ConsistentHashProvider - Class in alluxio.client.file.dora
-
A consistent hashing algorithm implementation.
- ConsistentHashProvider(int, long) - Constructor for class alluxio.client.file.dora.ConsistentHashProvider
-
Constructor.
- ConsistentUnderFileSystem - Class in alluxio.underfs
-
Represents a consistent under filesystem
which does not have eventual consistency issues.
- ConsistentUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.ConsistentUnderFileSystem
-
- ConsoleSink - Class in alluxio.metrics.sink
-
A sink which outputs metric values to the console.
- ConsoleSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.ConsoleSink
-
- constantExecutorServiceFactory(ExecutorService) - Static method in class alluxio.util.executor.ExecutorServiceFactories
-
- Constants - Class in alluxio
-
System wide constants.
- Constraint - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.Constraint
- Constraint.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.Constraint
- CONSTRAINT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ReadTablePRequest
-
- ConstraintOrBuilder - Interface in alluxio.grpc.table
-
- CONTAINER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
- CONTAINERHOST_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerNetAddress
-
- ContainerIdGenerable - Interface in alluxio.master.block
-
Provides generation of container IDs.
- contains(Object) - Method in class alluxio.collections.ConcurrentHashSet
-
- contains(Object) - Method in class alluxio.collections.DelegatingSet
-
- contains(T) - Method in class alluxio.collections.DirectedAcyclicGraph
-
Checks if a node with the given payload is in the DAG.
- contains(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
-
Whether there is an object with the specified index field value in the set.
- contains(Object) - Method in class alluxio.collections.UnmodifiableArrayList
-
- contains(Scope, Scope) - Static method in class alluxio.grpc.GrpcUtils
-
- contains(AclAction) - Method in class alluxio.security.authorization.AclActions
-
- containsAddedBlocksOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- containsAddedBlocksOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- containsAddedBlocksOnTiers(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- containsAll(Collection<?>) - Method in class alluxio.collections.ConcurrentHashSet
-
- containsAll(Collection<?>) - Method in class alluxio.collections.DelegatingSet
-
- containsAll(Collection<?>) - Method in class alluxio.collections.UnmodifiableArrayList
-
- containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
map<string, int64> capacityBytesOnTiers = 2;
- containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
map<string, int64> capacityBytesOnTiers = 2;
- containsCapacityBytesOnTiers(String) - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
map<string, int64> capacityBytesOnTiers = 2;
- containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
map<string, int64> capacityBytesOnTiers = 2;
- containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.BlockMasterInfo
-
map<string, int64> capacityBytesOnTiers = 2;
- containsCapacityBytesOnTiers(String) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
map<string, int64> capacityBytesOnTiers = 2;
- containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.WorkerInfo.Builder
-
map<string, int64> capacityBytesOnTiers = 8;
- containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.WorkerInfo
-
map<string, int64> capacityBytesOnTiers = 8;
- containsCapacityBytesOnTiers(String) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
map<string, int64> capacityBytesOnTiers = 8;
- containsColumn(String) - Method in class alluxio.grpc.table.FileStatistics.Builder
-
map column names to column statistics
- containsColumn(String) - Method in class alluxio.grpc.table.FileStatistics
-
map column names to column statistics
- containsColumn(String) - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
-
map column names to column statistics
- containsColumnConstraints(String) - Method in class alluxio.grpc.table.Constraint.Builder
-
maps column to constraint, columns not present are not constrained
- containsColumnConstraints(String) - Method in class alluxio.grpc.table.Constraint
-
maps column to constraint, columns not present are not constrained
- containsColumnConstraints(String) - Method in interface alluxio.grpc.table.ConstraintOrBuilder
-
maps column to constraint, columns not present are not constrained
- containsCreate(int) - Static method in class alluxio.fuse.AlluxioFuseOpenUtils
-
Checks if the open flag contains create open flag.
- containsCurrentBlocksOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- containsCurrentBlocksOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- containsCurrentBlocksOnTiers(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- containsErrors(String) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Scope name as key
- containsErrors(String) - Method in class alluxio.grpc.ConfigCheckReport
-
Scope name as key
- containsErrors(String) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Scope name as key
- containsErrors(String) - Method in class alluxio.grpc.PolicyStatus.Builder
-
map<string, string> errors = 10;
- containsErrors(String) - Method in class alluxio.grpc.PolicyStatus
-
map<string, string> errors = 10;
- containsErrors(String) - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
map<string, string> errors = 10;
- containsField(V) - Method in interface alluxio.collections.FieldIndex
-
Returns whether there is an object with the specified index field value in the set.
- containsField(V) - Method in class alluxio.collections.NonUniqueFieldIndex
-
- containsField(V) - Method in class alluxio.collections.UniqueFieldIndex
-
- containsInterruptedException(Throwable) - Static method in class alluxio.util.ExceptionUtils
-
- containsKey(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
-
- containsKey(K) - Method in class alluxio.collections.LockPool
-
Returns whether the pool contains a particular key.
- containsLocalIp(List<InetSocketAddress>, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
-
- containsLostStorage(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of lost storage paths on all tiers
- containsLostStorage(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of lost storage paths on all tiers
- containsLostStorage(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of lost storage paths on all tiers
- containsLostStorage(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of tier alias to a list of lost storage paths.
- containsLostStorage(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of tier alias to a list of lost storage paths.
- containsLostStorage(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of tier alias to a list of lost storage paths.
- containsLostStorage(String) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
a map from tier alias to the lost storage paths
- containsLostStorage(String) - Method in class alluxio.grpc.WorkerLostStorageInfo
-
a map from tier alias to the lost storage paths
- containsLostStorage(String) - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
-
a map from tier alias to the lost storage paths
- containsMetrics(String) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- containsMetrics(String) - Method in class alluxio.grpc.GetMetricsPResponse
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- containsMetrics(String) - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- containsMountPoint(AlluxioURI, boolean) - Method in class alluxio.master.file.meta.MountTable
-
- containsMountPoints(String) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- containsMountPoints(String) - Method in class alluxio.grpc.GetMountTablePResponse
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- containsMountPoints(String) - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- containsObject(T) - Method in interface alluxio.collections.FieldIndex
-
Returns whether there is an object in the set.
- containsObject(T) - Method in class alluxio.collections.NonUniqueFieldIndex
-
- containsObject(T) - Method in class alluxio.collections.UniqueFieldIndex
-
- containsOptions(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
map<string, string> options = 5;
- containsOptions(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
map<string, string> options = 5;
- containsOptions(String) - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
map<string, string> options = 5;
- containsParameter(String) - Method in class alluxio.grpc.table.Database.Builder
-
map<string, string> parameter = 4;
- containsParameter(String) - Method in class alluxio.grpc.table.Database
-
map<string, string> parameter = 4;
- containsParameter(String) - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
map<string, string> parameter = 4;
- containsParameters(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
map<string, string> parameters = 7;
- containsParameters(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
map<string, string> parameters = 7;
- containsParameters(String) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
map<string, string> parameters = 7;
- containsParameters(String) - Method in class alluxio.grpc.table.TableInfo.Builder
-
map<string, string> parameters = 7;
- containsParameters(String) - Method in class alluxio.grpc.table.TableInfo
-
map<string, string> parameters = 7;
- containsParameters(String) - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
map<string, string> parameters = 7;
- containsPartitionStatistics(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- containsPartitionStatistics(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- containsPartitionStatistics(String) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- containsPathConfigs(String) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- containsPathConfigs(String) - Method in class alluxio.grpc.GetConfigurationPResponse
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- containsPathConfigs(String) - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- containsProperties(String) - Method in class alluxio.grpc.MountPointInfo.Builder
-
map<string, string> properties = 6;
- containsProperties(String) - Method in class alluxio.grpc.MountPointInfo
-
map<string, string> properties = 6;
- containsProperties(String) - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
map<string, string> properties = 6;
- containsProperties(String) - Method in class alluxio.grpc.MountPOptions.Builder
-
map<string, string> properties = 2;
- containsProperties(String) - Method in class alluxio.grpc.MountPOptions
-
map<string, string> properties = 2;
- containsProperties(String) - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
map<string, string> properties = 2;
- containsProperties(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
map<string, string> properties = 2;
- containsProperties(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
map<string, string> properties = 2;
- containsProperties(String) - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
map<string, string> properties = 2;
- containsProperties(String) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
map<string, string> properties = 1;
- containsProperties(String) - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
map<string, string> properties = 1;
- containsProperties(String) - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
-
map<string, string> properties = 1;
- containsProperties(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
map<string, string> properties = 2;
- containsProperties(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
map<string, string> properties = 2;
- containsProperties(String) - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
-
map<string, string> properties = 2;
- containsSerdelibParameters(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
map<string, string> serdelib_parameters = 4;
- containsSerdelibParameters(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
map<string, string> serdelib_parameters = 4;
- containsSerdelibParameters(String) - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
map<string, string> serdelib_parameters = 4;
- containsSerdeParameters(String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
map<string, string> serde_parameters = 5;
- containsSerdeParameters(String) - Method in class alluxio.grpc.table.layout.hive.Storage
-
map<string, string> serde_parameters = 5;
- containsSerdeParameters(String) - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
map<string, string> serde_parameters = 5;
- containsStats(String) - Method in class alluxio.grpc.table.Layout.Builder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- containsStats(String) - Method in class alluxio.grpc.table.Layout
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- containsStats(String) - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- containsStatus(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
map<string, bool> status = 1;
- containsStatus(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
map<string, bool> status = 1;
- containsStatus(String) - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
-
map<string, bool> status = 1;
- containsTablesErrors(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
map<string, string> tables_errors = 1;
- containsTablesErrors(String) - Method in class alluxio.grpc.table.SyncStatus
-
map<string, string> tables_errors = 1;
- containsTablesErrors(String) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
map<string, string> tables_errors = 1;
- containsTags(String) - Method in class alluxio.grpc.Metric.Builder
-
map<string, string> tags = 6;
- containsTags(String) - Method in class alluxio.grpc.Metric
-
map<string, string> tags = 6;
- containsTags(String) - Method in interface alluxio.grpc.MetricOrBuilder
-
map<string, string> tags = 6;
- containsTotalBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of total bytes on each tier
- containsTotalBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of total bytes on each tier
- containsTotalBytesOnTiers(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of total bytes on each tier
- containsTruncate(int) - Static method in class alluxio.fuse.AlluxioFuseOpenUtils
-
Checks if the open flag contains truncate open flag.
- containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of space used in bytes on all tiers
- containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of space used in bytes on all tiers
- containsUsedBytesOnTiers(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of space used in bytes on all tiers
- containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
map<string, int64> usedBytesOnTiers = 7;
- containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.BlockMasterInfo
-
map<string, int64> usedBytesOnTiers = 7;
- containsUsedBytesOnTiers(String) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
map<string, int64> usedBytesOnTiers = 7;
- containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of used bytes on each tier
- containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of used bytes on each tier
- containsUsedBytesOnTiers(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of used bytes on each tier
- containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.WorkerInfo.Builder
-
map<string, int64> usedBytesOnTiers = 9;
- containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.WorkerInfo
-
map<string, int64> usedBytesOnTiers = 9;
- containsUsedBytesOnTiers(String) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
map<string, int64> usedBytesOnTiers = 9;
- containsValue(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
-
- containsValues(String) - Method in class alluxio.grpc.InconsistentProperty.Builder
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- containsValues(String) - Method in class alluxio.grpc.InconsistentProperty
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- containsValues(String) - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- containsWarns(String) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Scope name as key
- containsWarns(String) - Method in class alluxio.grpc.ConfigCheckReport
-
Scope name as key
- containsWarns(String) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Scope name as key
- containsWildcard() - Method in class alluxio.AlluxioURI
-
Whether or not the
AlluxioURI
contains wildcard(s).
- containsXattr(String) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
map<string, bytes> xattr = 6;
- containsXattr(String) - Method in class alluxio.grpc.CreateDirectoryPOptions
-
map<string, bytes> xattr = 6;
- containsXattr(String) - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
map<string, bytes> xattr = 6;
- containsXattr(String) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
map<string, bytes> xattr = 11;
- containsXattr(String) - Method in class alluxio.grpc.CreateFilePOptions
-
map<string, bytes> xattr = 11;
- containsXattr(String) - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
map<string, bytes> xattr = 11;
- containsXattr(String) - Method in class alluxio.grpc.FileInfo.Builder
-
map<string, bytes> xattr = 32;
- containsXattr(String) - Method in class alluxio.grpc.FileInfo
-
map<string, bytes> xattr = 32;
- containsXattr(String) - Method in interface alluxio.grpc.FileInfoOrBuilder
-
map<string, bytes> xattr = 32;
- containsXattr(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
map<string, bytes> xattr = 11;
- containsXattr(String) - Method in class alluxio.grpc.SetAttributePOptions
-
map<string, bytes> xattr = 11;
- containsXattr(String) - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
map<string, bytes> xattr = 11;
- containsXattr(String) - Method in class alluxio.grpc.UfsStatus.Builder
-
map<string, bytes> xattr = 7;
- containsXattr(String) - Method in class alluxio.grpc.UfsStatus
-
map<string, bytes> xattr = 7;
- containsXattr(String) - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
map<string, bytes> xattr = 7;
- containsXAttr(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
map<string, bytes> xAttr = 19;
- containsXAttr(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
map<string, bytes> xAttr = 19;
- containsXAttr(String) - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
map<string, bytes> xAttr = 19;
- containsXAttr(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
map<string, bytes> xAttr = 28;
- containsXAttr(String) - Method in class alluxio.proto.journal.File.InodeFileEntry
-
map<string, bytes> xAttr = 28;
- containsXAttr(String) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
map<string, bytes> xAttr = 28;
- containsXAttr(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
map<string, bytes> xAttr = 17;
- containsXAttr(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
map<string, bytes> xAttr = 17;
- containsXAttr(String) - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
map<string, bytes> xAttr = 17;
- containsXAttr(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
Extended attributes, general purpose.
- containsXAttr(String) - Method in class alluxio.proto.meta.InodeMeta.Inode
-
Extended attributes, general purpose.
- containsXAttr(String) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
Extended attributes, general purpose.
- Content(String, String, String) - Constructor for class alluxio.s3.ListBucketResult.Content
-
- Content(String, String, String, boolean) - Constructor for class alluxio.s3.ListBucketResult.Content
-
- CONTENT_HASH_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsFileStatus
-
- CONTENT_LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsFileStatus
-
- CONTENT_TYPE_XATTR_KEY - Static variable in class alluxio.s3.S3Constants
-
- CONTENTHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.CompleteFilePOptions
-
- CONTENTHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
-
- CONTENTHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteResponse
-
- ContentHashable - Interface in alluxio.underfs
-
Interface for returning the content hash.
- Context - Class in alluxio.cli.fsadmin.command
-
Context for running an fsadmin command.
- Context(FileSystemMasterClient, BlockMasterClient, MetaMasterClient, MetricsMasterClient, JournalMasterClient, JournalMasterClient, JobMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.command.Context
-
- continueTask() - Method in class alluxio.proxy.s3.S3BaseTask
-
Run core S3 API logic from different S3 task.
- continueTask() - Method in class alluxio.proxy.s3.S3BucketTask
-
- continueTask() - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
-
- continueTask() - Method in class alluxio.proxy.s3.S3ObjectTask
-
- continueTask() - Method in class alluxio.worker.s3.S3NettyBaseTask
-
Run core S3 API logic from different S3 task.
- continueTask() - Method in class alluxio.worker.s3.S3NettyBucketTask
-
- continueTask() - Method in class alluxio.worker.s3.S3NettyObjectTask
-
- ControllableQueue<T> - Class in alluxio.util.executor
-
- ControllableQueue() - Constructor for class alluxio.util.executor.ControllableQueue
-
- ControllableQueue.DelayNode<T> - Class in alluxio.util.executor
-
A delay node in delta queue which records the value
and the total delay (which is the original delay plus the past time).
- ControllableScheduler - Class in alluxio.util.executor
-
A controllable scheduler supports jump to a future time and run all
commands within that time period.
- ControllableScheduler() - Constructor for class alluxio.util.executor.ControllableScheduler
-
- convert(String) - Method in class alluxio.cli.TestRunner.WorkerAddressConverter
-
- convert(String) - Method in class alluxio.stress.client.ClientIOParameters.ClientIOOperationConverter
-
- convert(String) - Method in class alluxio.stress.common.FileSystemParameters.FileSystemParametersClientTypeConverter
-
- convert(String) - Method in class alluxio.stress.common.FileSystemParameters.FileSystemParametersReadTypeConverter
-
- convert(String) - Method in class alluxio.stress.common.FileSystemParameters.FileSystemParametersWriteTypeConverter
-
- convertAclToStringEntries() - Method in class alluxio.wire.FileInfo
-
- convertAddressToStringWebPort(WorkerNetAddress) - Static method in class alluxio.cli.fsadmin.command.WorkerAddressUtils
-
Converts a worker address to string.
- convertAlluxioPathToUfsPath(AlluxioURI, AlluxioURI) - Static method in class alluxio.util.io.PathUtils
-
Converts the Alluxio based path to UfsBaseFileSystem based path if needed.
- convertBlockListMapToProto(Map<BlockStoreLocation, List<Long>>) - Method in class alluxio.worker.block.BlockMasterClient
-
Converts the block list map to a proto list.
- convertByteArrayToStringWithoutEscape(byte[], int, int) - Static method in class alluxio.util.webui.WebUtils
-
Converts a byte array to string.
- convertDefaultAclToStringEntries() - Method in class alluxio.wire.FileInfo
-
- convertFromByteString(Map<String, ByteString>) - Static method in class alluxio.util.CommonUtils
-
- convertMsToClockTime(long) - Static method in class alluxio.util.CommonUtils
-
Converts milliseconds to clock time.
- convertMsToDate(long, String) - Static method in class alluxio.util.CommonUtils
-
Converts a millisecond number to a formatted date String.
- convertResults(List<ValidationTaskResult>) - Static method in interface alluxio.cli.ValidationTool
-
- convertToAlluxioPath(AlluxioURI) - Method in class alluxio.client.file.DoraCacheFileSystem
-
Converts the UFS path back to Alluxio path.
- convertToByteString(Map<String, byte[]>) - Static method in class alluxio.util.CommonUtils
-
- convertToFolderName(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Appends the directory suffix to the key.
- convertToNames(UfsStatus[]) - Static method in class alluxio.underfs.UfsStatus
-
Converts an array of UFS file status to a listing result where each element in the array is
a file or directory name.
- convertToSingleValueMap(HttpHeaders) - Static method in class alluxio.s3.NettyRestUtils
-
Convert HttpHeaders
to a single value map.
- convertToUfsPath(AlluxioURI) - Method in class alluxio.client.file.DoraCacheFileSystem
-
Converts the Alluxio based path to UfsBaseFileSystem based path if needed.
- convertUfsPathToAlluxioPath(AlluxioURI, AlluxioURI) - Static method in class alluxio.util.io.PathUtils
-
Converts the UFS path back to Alluxio path.
- coordinators() - Method in class alluxio.master.job.plan.PlanTracker
-
- copy(CopyRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
-
copy files from src to dst.
- copy(CopyRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- copy() - Method in class alluxio.concurrent.jsr.CompletableFuture
-
Returns a new CompletableFuture that is completed normally with the same value as this
CompletableFuture when it completes normally.
- copy() - Method in class alluxio.conf.AlluxioProperties
-
Makes a copy of the backing properties and returns them in a new object.
- copy(CopyRequest, StreamObserver<CopyResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
-
- copy(CopyRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
-
- copy(CopyRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
-
- copy(CopyRequest, StreamObserver<CopyResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
-
- copy() - Method in class alluxio.underfs.UfsDirectoryStatus
-
- copy() - Method in class alluxio.underfs.UfsFileStatus
-
- copy() - Method in class alluxio.underfs.UfsStatus
-
- copy(List<Route>, UfsReadOptions, WriteOptions) - Method in interface alluxio.worker.dora.DoraWorker
-
Copies files from src to dst.
- copy(List<Route>, UfsReadOptions, WriteOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- copy(CopyRequest, StreamObserver<CopyResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
-
- copy(Route, WriteOptions, FileSystem, FileSystem) - Static method in class alluxio.worker.task.CopyHandler
-
Copies a file from source to destination.
- COPY_FAIL_FILE_COUNT - Static variable in class alluxio.master.job.CopyJob
-
- COPY_FILE_COUNT - Static variable in class alluxio.master.job.CopyJob
-
- COPY_JOB_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
-
- COPY_RATE - Static variable in class alluxio.master.job.CopyJob
-
- COPY_SIZE - Static variable in class alluxio.master.job.CopyJob
-
- COPY_SKIP_FILE_COUNT - Static variable in class alluxio.master.job.CopyJob
-
- copyAndMaskProperties(MountPOptions.Builder, Map<String, String>) - Method in class alluxio.RpcSensitiveConfigMask
-
- copyGlobal() - Static method in class alluxio.conf.Configuration
-
- CopyHandler - Class in alluxio.worker.task
-
CopyHandler is responsible for copying files.
- CopyHandler() - Constructor for class alluxio.worker.task.CopyHandler
-
- CopyJob - Class in alluxio.master.job
-
Copy job that copy a file or a directory from source to destination.
- CopyJob(String, String, boolean, Optional<String>, String, OptionalLong, boolean, boolean, boolean, Iterable<FileInfo>, Optional<Job.FileFilter>) - Constructor for class alluxio.master.job.CopyJob
-
Constructor.
- CopyJob.CopyTask - Class in alluxio.master.job
-
Loads blocks in a UFS through an Alluxio worker.
- CopyJobFactory - Class in alluxio.master.job
-
Factory for creating
CopyJob
s that get file infos from master.
- CopyJobFactory(CopyJobRequest, DefaultFileSystemMaster) - Constructor for class alluxio.master.job.CopyJobFactory
-
Create factory.
- CopyJobPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CopyJobPOptions
- CopyJobPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CopyJobPOptions
- CopyJobPOptionsOrBuilder - Interface in alluxio.grpc
-
- CopyJobRequest - Class in alluxio.job
-
The request of copying files.
- CopyJobRequest(String, String, CopyJobPOptions) - Constructor for class alluxio.job.CopyJobRequest
-
- copyObject(String, String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- copyObject(String, String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- copyObject(String, String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- copyObject(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Copies an object to another key.
- copyObject(String, String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- copyObject(String, String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- copyObject(String, String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- CopyObjectResult - Class in alluxio.s3
-
Result of an S3 Copy.
- CopyObjectResult(String, long) - Constructor for class alluxio.s3.CopyObjectResult
-
- CopyPartResult - Class in alluxio.proxy.s3
-
Result of an S3 UploadPartCopy.
- CopyPartResult(String) - Constructor for class alluxio.proxy.s3.CopyPartResult
-
- copyProperties() - Method in interface alluxio.conf.AlluxioConfiguration
-
- copyProperties() - Static method in class alluxio.conf.Configuration
-
Create and return a copy of all properties.
- copyProperties() - Method in class alluxio.conf.InstancedConfiguration
-
- copyProperties() - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- CopyRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.CopyRequest
- CopyRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.CopyRequest
- CopyRequestOrBuilder - Interface in alluxio.grpc
-
- CopyResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.CopyResponse
- CopyResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.CopyResponse
- CopyResponseOrBuilder - Interface in alluxio.grpc
-
- CopyTask(List<Route>) - Constructor for class alluxio.master.job.CopyJob.CopyTask
-
- CoreMaster - Class in alluxio.master
-
Abstract class for masters that run in the core master process.
- CoreMaster(CoreMasterContext, Clock, ExecutorServiceFactory) - Constructor for class alluxio.master.CoreMaster
-
- CoreMasterContext - Class in alluxio.master
-
This class stores fields that are specific to core masters.
- CoreMasterContext.Builder - Class in alluxio.master
-
- CORSFilter - Class in alluxio.web
-
A filter for adding the Cors header to the http header.
- CORSFilter() - Constructor for class alluxio.web.CORSFilter
-
- COS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
-
- COS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
-
- COS_APP_ID - Static variable in class alluxio.conf.PropertyKey
-
- COS_APP_ID - Static variable in class alluxio.conf.PropertyKey.Name
-
- COS_CONNECTION_MAX - Static variable in class alluxio.conf.PropertyKey
-
- COS_CONNECTION_MAX - Static variable in class alluxio.conf.PropertyKey.Name
-
- COS_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
-
- COS_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
-
- COS_REGION - Static variable in class alluxio.conf.PropertyKey
-
- COS_REGION - Static variable in class alluxio.conf.PropertyKey.Name
-
- COS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
-
- COS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
-
- COS_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
-
- COS_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
-
- COSInputStream - Class in alluxio.underfs.cos
-
A stream for reading a file from COS.
- COSMultipartUploadOutputStream - Class in alluxio.underfs.cos
-
Object storage multipart upload for COS.
- COSMultipartUploadOutputStream(String, String, COS, ListeningExecutorService, AlluxioConfiguration) - Constructor for class alluxio.underfs.cos.COSMultipartUploadOutputStream
-
Constructs a new stream for writing a file.
- CosnUfsConstants - Class in alluxio
-
Ufs constants from compilation time by maven.
- CosnUnderFileSystem - Class in alluxio.underfs.cosn
-
- CosnUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.cosn.CosnUnderFileSystem
-
- CosNUnderFileSystemFactory - Class in alluxio.underfs.cosn
-
- CosNUnderFileSystemFactory() - Constructor for class alluxio.underfs.cosn.CosNUnderFileSystemFactory
-
- COSOutputStream - Class in alluxio.underfs.cos
-
A stream for writing a file into COS.
- COSOutputStream(String, String, COSClient, List<String>) - Constructor for class alluxio.underfs.cos.COSOutputStream
-
- COSPositionReader - Class in alluxio.underfs.cos
-
- COSPositionReader(COSClient, String, String, long) - Constructor for class alluxio.underfs.cos.COSPositionReader
-
- COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
-
- COSUnderFileSystem - Class in alluxio.underfs.cos
-
- COSUnderFileSystem(AlluxioURI, COSClient, String, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.cos.COSUnderFileSystem
-
- COSUnderFileSystemFactory - Class in alluxio.underfs.cos
-
- COSUnderFileSystemFactory() - Constructor for class alluxio.underfs.cos.COSUnderFileSystemFactory
-
- COUNT_FIELD_NUMBER - Static variable in class alluxio.grpc.StatusSummary
-
- CountedCompleter<T> - Class in alluxio.concurrent.jsr
-
A
ForkJoinTask
with a completion action performed when triggered and there are no
remaining pending actions.
- CountedCompleter(CountedCompleter<?>, int) - Constructor for class alluxio.concurrent.jsr.CountedCompleter
-
Creates a new CountedCompleter with the given completer and initial pending count.
- CountedCompleter(CountedCompleter<?>) - Constructor for class alluxio.concurrent.jsr.CountedCompleter
-
Creates a new CountedCompleter with the given completer and an initial pending count of zero.
- CountedCompleter() - Constructor for class alluxio.concurrent.jsr.CountedCompleter
-
Creates a new CountedCompleter with no completer and an initial pending count of zero.
- counter(String) - Static method in class alluxio.metrics.MetricsSystem
-
Get or add counter with the given name.
- COUNTER_VALUE - Static variable in enum alluxio.grpc.MetricType
-
COUNTER represents values which can be incremented or decremented over time by certain operations.
- counterWithTags(String, boolean, String...) - Static method in class alluxio.metrics.MetricsSystem
-
Get or add counter with the given name with tags.
- CountingLatch - Class in alluxio.concurrent
-
Similar to
CountDownLatch
except that the count can either be
increased or decreased.
- CountingLatch() - Constructor for class alluxio.concurrent.CountingLatch
-
- CountingRetry - Class in alluxio.retry
-
An option which allows retrying based on maximum count.
- CountingRetry(int) - Constructor for class alluxio.retry.CountingRetry
-
Constructs a retry facility which allows max number of retries.
- CpCommand - Class in alluxio.cli.fs.command
-
Copies a file or a directory in the Alluxio filesystem.
- CpCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.CpCommand
-
- crashed() - Method in class alluxio.thread.AutopsyThread
-
Checks if the thread has crashed.
- create(Map<Object, Object>) - Method in class alluxio.cli.HdfsValidationToolFactory
-
- create(Map<Object, Object>) - Static method in class alluxio.cli.HmsValidationTool
-
- create(Map<Object, Object>) - Method in class alluxio.cli.HmsValidationToolFactory
-
- create(Map<Object, Object>) - Method in interface alluxio.cli.ValidationToolFactory
-
- create(String, Map<Object, Object>) - Method in class alluxio.cli.ValidationToolRegistry
-
- create(MasterClientContext) - Static method in class alluxio.client.block.BlockMasterClient.Factory
-
- create(FileSystemContext) - Static method in class alluxio.client.block.BlockStoreClient
-
Creates an Alluxio block store with default local hostname.
- create(UserState, GrpcServerAddress, AlluxioConfiguration) - Static method in class alluxio.client.block.stream.BlockWorkerClient.Factory
-
Creates a new block worker client.
- create(long, long) - Method in class alluxio.client.block.stream.BlockWorkerDataReader.Factory
-
- create(FileSystemContext, long, long, OutStreamOptions) - Static method in class alluxio.client.block.stream.BlockWorkerDataWriter
-
- create(FileSystemContext, WorkerNetAddress, ReadRequest) - Static method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
-
- create(long, long) - Method in interface alluxio.client.block.stream.DataReader.Factory
-
- create(FileSystemContext, long, long, WorkerNetAddress, OutStreamOptions) - Static method in class alluxio.client.block.stream.DataWriter.Factory
-
- create(long, long) - Method in class alluxio.client.block.stream.GrpcDataReader.Factory
-
- create(FileSystemContext, WorkerNetAddress, long, long, RequestType, OutStreamOptions) - Static method in class alluxio.client.block.stream.GrpcDataWriter
-
- create(long, long) - Method in class alluxio.client.block.stream.NettyDataReader.Factory
-
- create(FileSystemContext, WorkerNetAddress, long, long, RequestType, OutStreamOptions) - Static method in class alluxio.client.block.stream.NettyDataWriter
-
- create(long, long) - Method in class alluxio.client.block.stream.SharedGrpcDataReader.Factory
-
- create(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.CacheManager.Factory
-
- create(AlluxioConfiguration, CacheManagerOptions, PageMetaStore) - Static method in class alluxio.client.file.cache.CacheManager.Factory
-
- create(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.CacheManagerOptions
-
- create(Funnel<? super T>, long, int, int, int, SlidingWindowType, long, double, double, HashFunction) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
Create a concurrent cuckoo filter with specified parameters.
- create(Funnel<? super T>, long, int, int, int, int, SlidingWindowType, long, double, double, HashFunction) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
Create a concurrent cuckoo filter with size encoder.
- create(Funnel<? super T>, long, int, int, int, SlidingWindowType, long, double, double) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
Create a concurrent cuckoo filter with specified parameters.
- create(Funnel<? super T>, long, int, int, int, SlidingWindowType, long, double) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
Create a concurrent cuckoo filter with specified parameters.
- create(Funnel<? super T>, long, int, int, int, SlidingWindowType, long) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
Create a concurrent cuckoo filter with specified parameters.
- create(Funnel<? super T>, long, int, int, int) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
Create a concurrent cuckoo filter with specified parameters.
- create(CacheEvictorOptions) - Static method in interface alluxio.client.file.cache.evictor.CacheEvictor
-
- create(AlluxioConfiguration) - Static method in interface alluxio.client.file.cache.filter.CacheFilter
-
Create a CacheFilter.
- create(CacheManagerOptions, PageMetaStore) - Static method in class alluxio.client.file.cache.LocalCacheManager
-
- create(AlluxioConfiguration, CacheManager, CloseableSupplier<PositionReader>, URIStatus, long, CacheContext) - Static method in class alluxio.client.file.cache.LocalCachePositionReader
-
- create(CacheManager, CloseableSupplier<PositionReader>, FileId, long, long, CacheContext) - Static method in class alluxio.client.file.cache.LocalCachePositionReader
-
- create(CacheManagerOptions) - Static method in interface alluxio.client.file.cache.PageMetaStore
-
- create(PageStoreOptions) - Static method in interface alluxio.client.file.cache.PageStore
-
Create an instance of PageStore.
- create(AlluxioConfiguration) - Static method in interface alluxio.client.file.cache.ShadowCacheManager
-
- create(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.store.PageStoreOptions
-
- create(FileSystemContext, WorkerNetAddress, long, RequestType, OutStreamOptions) - Static method in class alluxio.client.file.dora.netty.NettyDataWriter
-
- create(AlluxioConfiguration) - Static method in class alluxio.client.file.dora.WorkerLocationPolicy.Factory
-
- create() - Static method in class alluxio.client.file.FileSystem.Factory
-
- create(AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystem.Factory
-
- create(ClientContext) - Static method in class alluxio.client.file.FileSystem.Factory
-
- create(FileSystemContext) - Static method in class alluxio.client.file.FileSystem.Factory
-
- create(FileSystemContext, FileSystemOptions) - Static method in class alluxio.client.file.FileSystem.Factory
-
- create(AlluxioConfiguration, List<InetSocketAddress>) - Static method in class alluxio.client.file.FileSystemContext
-
Creates a
FileSystemContext
with an empty subject
, a null local block worker, and the given master addresses.
- create() - Static method in class alluxio.client.file.FileSystemContext
-
Creates a
FileSystemContext
with an empty subject, default config
and a null local block worker.
- create(AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemContext
-
- create(Subject, AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemContext
-
- create(ClientContext) - Static method in class alluxio.client.file.FileSystemContext
-
- create(ClientContext, BlockWorker) - Static method in class alluxio.client.file.FileSystemContext
-
- create(ClientContext, BlockWorker, List<InetSocketAddress>) - Static method in class alluxio.client.file.FileSystemContext
-
- create(Subject, MasterInquireClient, AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemContext
-
- create(AlluxioConfiguration, List<InetSocketAddress>) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
-
Creates a
FileSystemContext
with an empty subject
, a null local block worker, and the given master addresses.
- create() - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
-
Creates a
FileSystemContext
with an empty subject, default config
and a null local block worker.
- create(AlluxioConfiguration) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
-
- create(Subject, AlluxioConfiguration) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
-
- create(ClientContext) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
-
- create(ClientContext, BlockWorker) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
-
- create(ClientContext, BlockWorker, List<InetSocketAddress>) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
-
- create(Subject, MasterInquireClient, AlluxioConfiguration) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
-
- create(MasterClientContext) - Static method in class alluxio.client.file.FileSystemMasterClient.Factory
-
- create(AlluxioConfiguration, UserState) - Static method in class alluxio.client.job.JobContext
-
Creates a job context.
- create(JobMasterClientContext) - Static method in class alluxio.client.job.JobMasterClient.Factory
-
- create(String) - Static method in class alluxio.client.quota.CacheScope
-
- create(MasterClientContext) - Static method in class alluxio.client.table.TableMasterClient.Factory
-
- create(Subject, AlluxioConfiguration) - Static method in class alluxio.ClientContext
-
A client context with information about the subject and configuration of the client.
- create(AlluxioConfiguration) - Static method in class alluxio.ClientContext
-
- create() - Static method in class alluxio.ClientContext
-
- create(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- create(String, CreateOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- create(String, S) - Method in interface alluxio.extensions.ExtensionFactory
-
Creates a new extension for the given path.
- create(String, long, FuseFileInfo) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- create(FileSystem, AlluxioConfiguration, FuseFileSystem) - Static method in class alluxio.fuse.auth.AuthPolicyFactory
-
- create(FileSystem, AlluxioConfiguration, Optional<FuseFileSystem>) - Static method in class alluxio.fuse.auth.CustomAuthPolicy
-
Creates a new custom auth policy.
- create(FileSystem, AlluxioConfiguration, Optional<FuseFileSystem>) - Static method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
-
Creates a new launch user auth policy.
- create(FileSystem, AlluxioConfiguration, Optional<FuseFileSystem>) - Static method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
-
Creates a new system auth policy.
- create(AuthPolicy, long, long) - Static method in class alluxio.fuse.file.CreateFileStatus
-
- create(FileSystem, AuthPolicy, FuseReadWriteLockManager, AlluxioURI, int, long) - Static method in class alluxio.fuse.file.FuseFileInOrOutStream
-
- create(FileSystem, FuseReadWriteLockManager, AlluxioURI) - Static method in class alluxio.fuse.file.FuseFileInStream
-
- create(FileSystem, AuthPolicy, FuseReadWriteLockManager, AlluxioURI, int, long) - Static method in class alluxio.fuse.file.FuseFileOutStream
-
- create(FileSystem, FuseReadWriteLockManager, AlluxioURI) - Static method in class alluxio.fuse.file.FusePositionReader
-
- create(FileSystem, AuthPolicy, FuseReadWriteLockManager, AlluxioURI, int, long) - Static method in class alluxio.fuse.file.FusePositionReadOrOutStream
-
- create(AlluxioURI, int, long) - Method in interface alluxio.fuse.file.FuseStreamFactory
-
Factory method for creating/opening a file
and creating an implementation of
FuseFileStream
.
- create(AlluxioURI, int, long) - Method in class alluxio.fuse.file.SimpleFuseStreamFactory
-
Factory method for creating/opening a file
and creating an implementation of
FuseFileStream
.
- create(FuseOptions) - Static method in class alluxio.fuse.meta.UpdateChecker
-
- create(String, long, FuseFileInfo) - Method in class alluxio.fuse.StackFS
-
- create(InetSocketAddress) - Static method in class alluxio.grpc.GrpcServerAddress
-
- create(String, SocketAddress) - Static method in class alluxio.grpc.GrpcServerAddress
-
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class alluxio.hadoop.AbstractFileSystem
-
Attempts to create a file.
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class alluxio.hadoop.LocalCacheFileSystem
-
- create(String, long, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
-
- create(String) - Static method in class alluxio.job.plan.batch.BatchedJobDefinition.JobDefinitionFactory
-
- create(CompositeConfig) - Method in class alluxio.job.workflow.composite.CompositeExecutionFactory
-
- create(T) - Method in interface alluxio.job.workflow.WorkflowExecutionFactory
-
- create() - Static method in class alluxio.master.AlluxioMasterProcess.Factory
-
- create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.block.BlockMasterFactory
-
- create(BlockMaster, long, StreamObserver<RegisterWorkerPRequest>) - Static method in class alluxio.master.block.WorkerRegisterContext
-
- create(FileSystemMasterView) - Static method in class alluxio.master.file.async.AsyncPersistHandler.Factory
-
- create(CheckAccessPOptions.Builder) - Static method in class alluxio.master.file.contexts.CheckAccessContext
-
- create(CheckConsistencyPOptions.Builder) - Static method in class alluxio.master.file.contexts.CheckConsistencyContext
-
- create(CompleteFilePOptions.Builder) - Static method in class alluxio.master.file.contexts.CompleteFileContext
-
- create(CreateDirectoryPOptions.Builder) - Static method in class alluxio.master.file.contexts.CreateDirectoryContext
-
- create(CreateFilePOptions.Builder) - Static method in class alluxio.master.file.contexts.CreateFileContext
-
- create(DeletePOptions.Builder) - Static method in class alluxio.master.file.contexts.DeleteContext
-
- create(ExistsPOptions.Builder) - Static method in class alluxio.master.file.contexts.ExistsContext
-
- create(FreePOptions.Builder) - Static method in class alluxio.master.file.contexts.FreeContext
-
- create(GetStatusPOptions.Builder) - Static method in class alluxio.master.file.contexts.GetStatusContext
-
- create(ListStatusPOptions.Builder) - Static method in class alluxio.master.file.contexts.ListStatusContext
-
- create(ListStatusPartialPOptions.Builder) - Static method in class alluxio.master.file.contexts.ListStatusContext
-
- create(LoadMetadataPOptions.Builder) - Static method in class alluxio.master.file.contexts.LoadMetadataContext
-
- create(MountPOptions.Builder) - Static method in class alluxio.master.file.contexts.MountContext
-
- create(RenamePOptions.Builder) - Static method in class alluxio.master.file.contexts.RenameContext
-
- create(ScheduleAsyncPersistencePOptions.Builder) - Static method in class alluxio.master.file.contexts.ScheduleAsyncPersistenceContext
-
- create(SetAclPOptions.Builder) - Static method in class alluxio.master.file.contexts.SetAclContext
-
- create(SetAttributePOptions.Builder) - Static method in class alluxio.master.file.contexts.SetAttributeContext
-
- create(FileSystemHeartbeatPOptions.Builder) - Static method in class alluxio.master.file.contexts.WorkerHeartbeatContext
-
- create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.file.FileSystemMasterFactory
-
- create(InodeStore, InodeDirectory) - Static method in class alluxio.master.file.meta.InodeTreeBufferedIterator
-
Creates buffered iterator with closeable interface.
- create(long, long, String, CreateDirectoryContext) - Static method in class alluxio.master.file.meta.MutableInodeDirectory
-
- create(long, long, String, long, CreateFileContext) - Static method in class alluxio.master.file.meta.MutableInodeFile
-
- create(MountTable, Clock) - Static method in class alluxio.master.file.meta.UfsAbsentPathCache.Factory
-
- create(MountTable) - Static method in class alluxio.master.file.meta.UfsBlockLocationCache.Factory
-
- create() - Method in class alluxio.master.job.CopyJobFactory
-
- create(JobRequest, DefaultFileSystemMaster) - Static method in class alluxio.master.job.JobFactoryProducer
-
- create(Journal.JournalEntry, DefaultFileSystemMaster) - Static method in class alluxio.master.job.JobFactoryProducer
-
- create() - Method in class alluxio.master.job.JournalCopyJobFactory
-
- create() - Method in class alluxio.master.job.JournalLoadJobFactory
-
- create() - Method in class alluxio.master.job.JournalMoveJobFactory
-
- create() - Method in class alluxio.master.job.LoadJobFactory
-
- create() - Method in class alluxio.master.job.MoveJobFactory
-
- create(CommandManager, JobServerContext, List<WorkerInfo>, Long, JobConfig, Consumer<PlanInfo>) - Static method in class alluxio.master.job.plan.PlanCoordinator
-
- create(URI) - Static method in class alluxio.master.journal.JournalFileParser.Factory
-
Creates a journal parser given the location.
- create(MasterRegistry, MasterContext) - Method in class alluxio.master.journal.JournalMasterFactory
-
- create(String) - Method in class alluxio.master.journalv0.Journal.Factory
-
- create(URI) - Static method in class alluxio.master.journalv0.Journal.Factory
-
Creates a new read-only journal using the given location.
- create(String) - Method in interface alluxio.master.journalv0.JournalFactory
-
Creates a new journal using the given name.
- create() - Static method in class alluxio.master.journalv0.JournalFormatter.Factory
-
- create(String) - Method in class alluxio.master.journalv0.MutableJournal.Factory
-
- create(URI) - Static method in class alluxio.master.journalv0.MutableJournal.Factory
-
Creates a new read-write journal using the given location.
- create() - Static method in class alluxio.master.LocalAlluxioMaster
-
Creates a new local Alluxio master with an isolated work directory and port.
- create(String) - Static method in class alluxio.master.LocalAlluxioMaster
-
Creates a new local Alluxio master with a isolated port.
- create(MasterRegistry, T) - Method in interface alluxio.master.MasterFactory
-
Factory method to create a new master instance.
- create(AlluxioConfiguration, UserState) - Static method in class alluxio.master.MasterInquireClient.Factory
-
- create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.meta.MetaMasterFactory
-
- create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.metrics.MetricsMasterFactory
-
- create(Job.FileFilter) - Method in class alluxio.master.predicate.DatePredicate.Factory
-
- create(Job.FileFilter) - Static method in interface alluxio.master.predicate.FilePredicate
-
Creates a file predicate from a file filter.
- create(Job.FileFilter) - Method in interface alluxio.master.predicate.FilePredicateFactory
-
Creates a predicate from a file filter.
- create(Job.FileFilter) - Method in class alluxio.master.predicate.TimePredicate.DateFromFileNameOlderThanFactory
-
- create(Job.FileFilter) - Method in class alluxio.master.predicate.TimePredicate.Factory
-
- create() - Static method in class alluxio.master.service.jvmmonitor.JvmMonitorService.Factory
-
- create() - Static method in class alluxio.master.service.metrics.MetricsService.Factory
-
- create(InetSocketAddress, MasterProcess, MasterRegistry) - Static method in class alluxio.master.service.rpc.RpcServerService.Factory
-
Creates a simple service wrapper around a grpc server to manager the grpc server for the
master process.
- create(InetSocketAddress, MasterProcess) - Static method in class alluxio.master.service.web.WebServerService.Factory
-
- create(AlluxioConfiguration) - Static method in class alluxio.membership.EtcdMembershipManager
-
- create() - Static method in class alluxio.membership.MasterMembershipManager
-
- create(AlluxioConfiguration) - Static method in class alluxio.membership.MembershipManager.Factory
-
- create(AlluxioConfiguration) - Static method in class alluxio.membership.StaticMembershipManager
-
- create() - Static method in class alluxio.proxy.ProxyProcess.Factory
-
- create(FileInStream, long, S3RangeSpec) - Static method in class alluxio.proxy.s3.RangeFileInStream.Factory
-
- create(S3Handler) - Static method in class alluxio.proxy.s3.S3BucketTask.Factory
-
Marshall the request and create corresponding bucket level S3 task.
- create(S3Handler) - Static method in class alluxio.proxy.s3.S3ObjectTask.Factory
-
Marshall the request and create corresponding object level S3 task.
- create(Iterator<? extends T>, Consumer<Void>) - Static method in class alluxio.resource.CloseableIterator
-
Wrap around an iterator with a resource to close.
- create(AlluxioConfiguration) - Static method in class alluxio.s3.auth.Authenticator.Factory
-
- create(String) - Static method in class alluxio.s3.S3RangeSpec.Factory
-
- create(String) - Static method in class alluxio.s3.signature.AwsCredential
-
Parse credential value.
- create() - Method in interface alluxio.scheduler.job.JobFactory
-
- create(AuthType, AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticationProvider.Factory
-
- create(Subject, AlluxioConfiguration, boolean) - Method in class alluxio.security.user.NoopUserState.Factory
-
- create(Subject, AlluxioConfiguration, boolean) - Method in class alluxio.security.user.SimpleUserState.Factory
-
- create(AlluxioConfiguration) - Static method in class alluxio.security.user.UserState.Factory
-
- create(AlluxioConfiguration, Subject) - Static method in class alluxio.security.user.UserState.Factory
-
- create(AlluxioConfiguration, Subject, CommonUtils.ProcessType) - Static method in class alluxio.security.user.UserState.Factory
-
- create(Subject, AlluxioConfiguration, boolean) - Method in interface alluxio.security.user.UserStateFactory
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystemFactory
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.adl.AdlUnderFileSystemFactory
-
- create(String) - Method in class alluxio.underfs.BaseUnderFileSystem
-
- create(String, CreateOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystemFactory
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystemFactory
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cos.COSUnderFileSystemFactory
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cosn.CosNUnderFileSystemFactory
-
- create(String, UfsStatus) - Static method in class alluxio.underfs.Fingerprint
-
Parses the input string and returns the fingerprint object.
- create(String, UfsStatus, String) - Static method in class alluxio.underfs.Fingerprint
-
Parses the input string and returns the fingerprint object.
- create(String, UfsStatus, String, AccessControlList) - Static method in class alluxio.underfs.Fingerprint
-
Parses the input string and returns the fingerprint object.
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.gcs.GCSUnderFileSystemFactory
-
- create(String, CreateOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
-
- create(String, CreateOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.local.LocalUnderFileSystemFactory
-
- create(String, CreateOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.obs.OBSUnderFileSystemFactory
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.oss.OSSUnderFileSystemFactory
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.ozone.OzoneUnderFileSystemFactory
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.s3a.S3AUnderFileSystemFactory
-
- create(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Creates a file in the under file system with the indicated name.
- create(String, CreateOptions) - Method in interface alluxio.underfs.UnderFileSystem
-
Creates a file in the under file system with the specified
CreateOptions
.
- create(String, AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
-
- create(String, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
-
Creates a client for operations involved with the under file system.
- create(String, UnderFileSystemConfiguration) - Method in interface alluxio.underfs.UnderFileSystemFactory
-
Creates a new client for accessing the given path.
- create(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- create(String, CreateOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.wasb.WasbUnderFileSystemFactory
-
- create(String) - Static method in class alluxio.uri.URI.Factory
-
Creates a
URI
from a string.
- create(String, Authority, String, String) - Static method in class alluxio.uri.URI.Factory
-
Creates a
URI
from components.
- create(URI, URI) - Static method in class alluxio.uri.URI.Factory
-
Resolves a child
URI
against a parent
URI
.
- create(URI, String, boolean) - Static method in class alluxio.uri.URI.Factory
-
- create() - Static method in class alluxio.util.compression.DirectoryMarshaller.Factory
-
- create() - Method in interface alluxio.util.executor.ExecutorServiceFactory
-
- create(AlluxioConfiguration) - Static method in class alluxio.util.network.tls.SslContextProvider.Factory
-
- create(AlluxioConfiguration, CacheManager, UnderFileSystem, String, String, long, long) - Static method in class alluxio.worker.dora.PagedFileReader
-
- create(JobMasterClientContext) - Static method in class alluxio.worker.job.JobMasterClient.Factory
-
- create() - Static method in class alluxio.worker.JobWorkerProcess.Factory
-
- create(T) - Method in interface alluxio.worker.netty.AbstractReadHandler.PacketReader.Factory
-
Creates a new packet reader.
- create(BlockReadRequest) - Method in class alluxio.worker.netty.FileReadHandler.FilePacketReaderFactory
-
- create(S3NettyHandler) - Static method in class alluxio.worker.s3.S3NettyBucketTask.Factory
-
Marshall the request and create corresponding bucket level S3 task.
- create(S3NettyHandler) - Static method in class alluxio.worker.s3.S3NettyObjectTask.Factory
-
Marshall the request and create corresponding object level S3 task.
- create() - Static method in class alluxio.worker.WorkerProcess.Factory
-
- CREATE_CHECK_FILE - Static variable in class alluxio.cli.fs.command.ConsistentHashCommand
-
- CREATE_DIRECTORY - Static variable in class alluxio.proxy.PathsRestServiceHandler
-
- CREATE_FILE - Static variable in class alluxio.proxy.PathsRestServiceHandler
-
- CREATE_UFS_FILE_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
-
- CREATE_UFS_FILE_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
-
- createAmazonS3(AWSCredentialsProvider, ClientConfiguration, AwsClientBuilder.EndpointConfiguration, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
Create an AmazonS3 client.
- createAmazonS3Async(UnderFileSystemConfiguration, ClientConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
Create an async S3 client.
- CREATEANCESTORS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadMetadataPOptions
-
- createAndAbortMultipartFileTest() - Method in class alluxio.cli.S3ASpecificOperations
-
Test for creating and aborting a multipart file.
- createAnInstance(FileSystem, FileSystemContext) - Method in class alluxio.client.file.DoraCacheFileSystem.DoraCacheFileSystemFactory
-
- createAtomicTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating file atomic.
- createAuditContext(String, AlluxioURI, AlluxioURI, Inode) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- createAuditContext(String, String, String, String) - Method in class alluxio.proxy.s3.S3Handler
-
- createAuditContext(String, String, String, String) - Method in class alluxio.worker.s3.S3NettyHandler
-
- createAwsCredentialsProvider(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- createBaseFileSystem(FileSystemContext, FuseOptions) - Method in class alluxio.fuse.AlluxioFuse
-
- createBaseMasterContext() - Method in class alluxio.master.AlluxioMasterProcess
-
- createBaseRpcServer() - Method in class alluxio.master.AlluxioJobMasterProcess
-
- createBaseRpcServer() - Method in class alluxio.master.AlluxioMasterProcess
-
- createBaseRpcServer() - Method in class alluxio.master.MasterProcess
-
- createBlock(long, long, int, CreateBlockOptions) - Method in interface alluxio.worker.block.BlockStore
-
Creates a block in Alluxio managed space.
- createBlock(long, long, int, CreateBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
-
Creates a block in Alluxio managed space.
- createBlockDeletionContext() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- createBlockId(long, long) - Static method in class alluxio.master.block.BlockId
-
- CreateBlockOptions - Class in alluxio.worker.block
-
Method options for create a block.
- CreateBlockOptions(String, String, long) - Constructor for class alluxio.worker.block.CreateBlockOptions
-
Constructor.
- createBlockPath(String, String) - Static method in class alluxio.util.io.FileUtils
-
Creates the local block path and all the parent directories.
- createBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockStore
-
Creates the block reader to read from Alluxio block or UFS block.
- createBlockReader(long, long, long) - Method in interface alluxio.worker.block.BlockStore
-
Creates a reader of an existing block to read data from this block.
- createBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
-
Creates the block reader to read from Alluxio block or UFS block.
- createBlockRemote(long, long, String, long) - Method in interface alluxio.worker.block.BlockWorker
-
Creates a block.
- createBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockStore
-
- createBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockWorker
-
- createBucket(String, String, String, String, InputStream) - Method in class alluxio.proxy.s3.S3RestServiceHandler
-
Creates a bucket, or puts bucket tags on an existing bucket.
- createCallback(String, long, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- createCancelResponse() - Static method in class alluxio.network.protocol.RPCProtoMessage
-
Creates a response in CANCELLED state.
- createCancelResponseEvent() - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
-
Create a CancelledResponseEvent.
- createChannel() - Method in class alluxio.AbstractClient
-
- createChannelErrorResponseEvent(Throwable) - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
-
Create a ChannelErrorResponseEvent.
- createCheckFile() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
-
Create the check file.
- createClientBootstrap(SocketAddress) - Static method in class alluxio.network.netty.NettyClient
-
Creates and returns a new Netty client bootstrap for clients to connect to remote servers.
- createCloseableIterator(RocksIterator, RocksUtils.RocksIteratorParser<T>, Supplier<Void>, RocksSharedLockHandle) - Static method in class alluxio.master.metastore.rocks.RocksUtils
-
- createConfiguration(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.adl.AdlUnderFileSystem
-
Prepares the configuration for this Adl as an HDFS configuration.
- createConfiguration(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
Prepares the Hadoop configuration necessary to successfully obtain a FileSystem
instance that can access the provided path.
- createConfiguration(UnderFileSystemConfiguration, Boolean) - Static method in class alluxio.underfs.wasb.WasbUnderFileSystem
-
Prepares the configuration for this Wasb as an HDFS configuration.
- CREATED_AT_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyInfo
-
- CREATED_AT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
- CREATED_VALUE - Static variable in enum alluxio.grpc.Status
-
CREATED = 1;
- CREATED_VALUE - Static variable in enum alluxio.proto.journal.Job.PJobState
-
CREATED = 1;
- createDataResponseEvent(DataBuffer) - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
-
Create a DataResponseEvent.
- createDatePredicate(String) - Method in class alluxio.master.predicate.DatePredicate.Factory
-
- createDeleteFileConjuctionTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and deleting file conjunction.
- createDir(String) - Static method in class alluxio.util.io.FileUtils
-
Creates an empty directory and its intermediate directories if necessary.
- createDirect(String, CreateOptions) - Method in interface alluxio.underfs.AtomicFileOutputStreamCallback
-
Creates a file in the under file system with the specified
CreateOptions
.
- createDirect(String, CreateOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- createDirect(String, CreateOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- createDirect(String, CreateOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- createDirectory(CreateDirectoryPRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
-
Create a directory.
- createDirectory(CreateDirectoryPRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
-
- createDirectory(String, CreateDirectoryPOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
-
Create a dir.
- createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
-
- createDirectory(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
-
- createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in interface alluxio.client.file.FileSystem
-
Creates a directory.
- createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Creates a new directory.
- createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.MetadataCachingFileSystem
-
- createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
-
Creates a directory.
- createDirectory(CreateDirectoryPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
-
Creates a directory.
- createDirectory(CreateDirectoryPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
-
Creates a directory.
- createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
-
Creates a directory.
- createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Creates a directory.
- createDirectory(CreateDirectoryPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Creates a directory.
- createDirectory(CreateDirectoryPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Creates a directory.
- createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Creates a directory.
- CreateDirectory - Class in alluxio.master.backcompat.ops
-
Test for directory creation.
- CreateDirectory() - Constructor for class alluxio.master.backcompat.ops.CreateDirectory
-
- createDirectory(AlluxioURI, CreateDirectoryContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- createDirectory(AlluxioURI, CreateDirectoryContext) - Method in interface alluxio.master.file.FileSystemMaster
-
Creates a directory for a given path.
- createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- createDirectory(String, CreateDirectoryPOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
-
- createDirectory(String, CreateDirectoryPOptions) - Method in interface alluxio.worker.dora.DoraWorker
-
Create a directory.
- createDirectory(String, CreateDirectoryPOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
-
- CreateDirectoryContext - Class in alluxio.master.file.contexts
-
- createDirectoryDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- createDirectoryDefaults(AlluxioConfiguration, boolean) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- CreateDirectoryPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateDirectoryPOptions
- CreateDirectoryPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateDirectoryPOptions
- CreateDirectoryPOptionsOrBuilder - Interface in alluxio.grpc
-
- CreateDirectoryPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateDirectoryPRequest
- CreateDirectoryPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateDirectoryPRequest
- CreateDirectoryPRequestOrBuilder - Interface in alluxio.grpc
-
- CreateDirectoryPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateDirectoryPResponse
- CreateDirectoryPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateDirectoryPResponse
- CreateDirectoryPResponseOrBuilder - Interface in alluxio.grpc
-
- createDomainSocketDataServer(DataWorker) - Method in class alluxio.worker.DataServerFactory
-
- createEmptyFileTest() - Method in class alluxio.cli.S3ASpecificOperations
-
Test for creating an empty file using streaming upload.
- createEmptyObject(String) - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
-
- createEmptyObject(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- createEmptyObject(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- createEmptyObject(String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- createEmptyObject(String) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
-
- createEmptyObject(String) - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
-
- createEmptyObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Creates a zero-byte object used to encode a directory.
- createEmptyObject(String) - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
-
- createEmptyObject(String) - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
-
- createEmptyObject(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- createEmptyObject(String) - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
-
- createEmptyObject(String) - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
-
- createEmptyObject(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- createEmptyObject(String) - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
-
- createEmptyObject(String) - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
-
- createEmptyObject(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- createEmptyTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating empty file.
- createEndpointConfiguration(UnderFileSystemConfiguration, ClientConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
Creates an endpoint configuration.
- createEofResponseEvent() - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
-
Create an EofResponseEvent.
- createErrorResponse(Throwable, String) - Static method in class alluxio.s3.S3ErrorResponse
-
Creates an error response using the given exception.
- createEventLoop(ChannelType, int, String, boolean) - Static method in class alluxio.util.network.NettyUtils
-
- createFile(CreateFilePRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
-
Create file request from client to worker.
- createFile(CreateFilePRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
-
- createFile(String, CreateFilePOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
-
Create File.
- createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
-
- createFile(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
-
- createFile(AlluxioURI, CreateFilePOptions) - Method in interface alluxio.client.file.FileSystem
-
Creates a file.
- createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- createFile(AlluxioURI, CreateFilePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Creates a new file.
- createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.MetadataCachingFileSystem
-
- createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- createFile(int, long) - Method in class alluxio.fsmaster.FileSystemMasterBase
-
- createFile(FileSystem, AuthPolicy, AlluxioURI, CreateFileStatus) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Creates a file in alluxio namespace.
- createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
-
Creates a file.
- createFile(CreateFilePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
-
Creates a file.
- createFile(CreateFilePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
-
Creates a file.
- createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
-
Creates a file.
- createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Creates a file.
- createFile(CreateFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Creates a file.
- createFile(CreateFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Creates a file.
- createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Creates a file.
- CreateFile - Class in alluxio.master.backcompat.ops
-
Test for file creation.
- CreateFile() - Constructor for class alluxio.master.backcompat.ops.CreateFile
-
- createFile(FileSystem, AlluxioURI) - Static method in class alluxio.master.backcompat.Utils
-
Creates a file at the given path.
- createFile(FileSystem, AlluxioURI, CreateFilePOptions) - Static method in class alluxio.master.backcompat.Utils
-
Creates a file at the given path.
- createFile(AlluxioURI, CreateFileContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- createFile(AlluxioURI, CreateFileContext) - Method in interface alluxio.master.file.FileSystemMaster
-
Creates a file (not a directory) for a given path.
- createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- createFile(String, CreateFilePOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
-
- createFile(String) - Static method in class alluxio.util.io.FileUtils
-
Creates an empty file and its intermediate directories if necessary.
- createFile(String, CreateFilePOptions) - Method in interface alluxio.worker.dora.DoraWorker
-
Create File.
- createFile(String, CreateFilePOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
-
- CreateFileContext - Class in alluxio.master.file.contexts
-
- createFileDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- createFileDefaults(AlluxioConfiguration, boolean) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- CreateFileEntry<T extends OutputStream> - Class in alluxio.fuse
-
Convenience class to encapsulate output stream
and its information (path, id) for create alluxio file.
- CreateFileEntry(long, String, T) - Constructor for class alluxio.fuse.CreateFileEntry
-
- createFileId(long) - Static method in class alluxio.util.IdUtils
-
Creates an id for a file based on the given id of the container.
- createFileLessThanOnePartTest() - Method in class alluxio.cli.S3ASpecificOperations
-
Test for creating a file with data less than one part.
- CreateFilePOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePOptions
- CreateFilePOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePOptions
- CreateFilePOptionsOrBuilder - Interface in alluxio.grpc
-
- CreateFilePRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePRequest
- CreateFilePRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePRequest
- CreateFilePRequestOrBuilder - Interface in alluxio.grpc
-
- CreateFilePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePResponse
- CreateFilePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePResponse
- CreateFilePResponseOrBuilder - Interface in alluxio.grpc
-
- createFileReader(String, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.dora.DoraWorker
-
Creates the file reader to read from Alluxio dora.
- createFileReader(String, long, boolean, Protocol.OpenUfsBlockOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- CreateFileStatus - Class in alluxio.fuse.file
-
The file status of ongoing fuse out stream.
- CreateFileStatus(long, long, long, long) - Constructor for class alluxio.fuse.file.CreateFileStatus
-
- createFileSystemContextId() - Static method in class alluxio.util.IdUtils
-
- createFileSystemForUser(String, FileSystem) - Static method in class alluxio.proxy.s3.S3RestUtils
-
- createFileWriter(String, String) - Method in interface alluxio.worker.dora.DoraWorker
-
Creates the file writer to write to Alluxio dora.
- createFileWriter(String, String) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- createForAddresses(List<InetSocketAddress>, AlluxioConfiguration, UserState) - Static method in class alluxio.master.MasterInquireClient.Factory
-
- createForJobMaster(AlluxioConfiguration, UserState) - Static method in class alluxio.master.MasterInquireClient.Factory
-
- createForPath(String, Optional<byte[]>) - Method in class alluxio.membership.AlluxioEtcdClient
-
Create a path with given value in non-transactional way.
- createForRoot(AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
-
- createForWorker(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.CacheManagerOptions
-
- createForWorkerPageStore(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.store.PageStoreOptions
-
- createFrameDecoder() - Static method in class alluxio.network.protocol.RPCMessage
-
Creates a decoder that splits up the incoming ByteBuf into new ByteBuf's according to a length
field in the input.
- createFullAccess() - Static method in class alluxio.security.authorization.Mode
-
Creates the "full access" mode.
- createFuseFileSystem(FileSystemContext, FileSystem, FuseOptions) - Method in class alluxio.fuse.AlluxioFuse
-
Create a FuseFileSystem instance.
- createGrpcDataReader(WorkerNetAddress, Protocol.OpenUfsBlockOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
-
- createHandler(String, HttpServletRequest, HttpServletResponse) - Static method in class alluxio.proxy.s3.S3Handler
-
Create a S3Handler based on the incoming Request.
- createHandler(ChannelHandlerContext, HttpRequest, FileSystem, DoraWorker, AsyncUserAccessAuditLogWriter) - Static method in class alluxio.worker.s3.S3NettyHandler
-
Create a S3Handler based on the incoming Request.
- CreateHmsClientValidationTask - Class in alluxio.cli.hms
-
A validation task that generates a new Hive Metastore client and verifies the connection.
- CreateHmsClientValidationTask(int, MetastoreValidationTask<?, String>) - Constructor for class alluxio.cli.hms.CreateHmsClientValidationTask
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.abfs.AbfsUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.adl.AdlUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cos.COSUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cosn.CosnUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.ozone.OzoneUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.wasb.WasbUnderFileSystem
-
- createInternalSessionId() - Static method in class alluxio.Sessions
-
- createJniFuseSystem(FileSystemContext, FileSystem, FuseOptions) - Method in class alluxio.fuse.AlluxioFuse
-
- createJournal(Master) - Method in interface alluxio.master.journal.JournalSystem
-
Creates a journal for the given state machine.
- createJournal(Master) - Method in class alluxio.master.journal.noop.NoopJournalSystem
-
- createJournal(Master) - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- createJournal(Master) - Method in class alluxio.master.journal.ufs.UfsJournalSystem
-
- createJournalContext() - Method in class alluxio.master.AbstractMaster
-
- createJournalContext() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- createJournalContext() - Method in interface alluxio.master.journal.Journal
-
- createJournalContext() - Method in class alluxio.master.journal.noop.NoopJournal
-
- createJournalContext() - Method in class alluxio.master.journal.raft.RaftJournal
-
- createJournalContext() - Method in class alluxio.master.journal.ufs.UfsJournal
-
- createJournalContext() - Method in interface alluxio.master.Master
-
- createJournalContext() - Method in class alluxio.master.NoopMaster
-
- createLease(long, long, TimeUnit) - Method in class alluxio.membership.AlluxioEtcdClient
-
Create a lease with timeout and ttl.
- createLease() - Method in class alluxio.membership.AlluxioEtcdClient
-
Create lease with default ttl and timeout.
- createLoginContext(AuthType, Subject, ClassLoader, Configuration, CallbackHandler) - Static method in class alluxio.util.SecurityUtils
-
- createMasters(MasterRegistry, MasterContext) - Static method in class alluxio.master.MasterUtils
-
Creates all the masters and registers them to the master registry.
- createMetaMasterConfigClient(MasterClientContext) - Method in class alluxio.client.file.ConfigHashSync
-
- createMountId() - Static method in class alluxio.util.IdUtils
-
- createMountSpecificConf(Map<String, ? extends Object>) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
Creates a new instance from the current configuration and adds in new properties.
- createMultipartFileTest() - Method in class alluxio.cli.S3ASpecificOperations
-
Test for creating a multipart file.
- createNettyDataReader(WorkerNetAddress, Protocol.OpenUfsBlockOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
-
- createNettyErrorResponse(Throwable, String) - Static method in class alluxio.s3.S3ErrorResponse
-
Creates an error response using the given exception.
- createNettyErrorResponse(S3Exception, String) - Static method in class alluxio.s3.S3ErrorResponse
-
Creates an error response using the given exception.
- createNettyPositionReader(URIStatus, Protocol.OpenUfsBlockOptions, Optional<CloseableSupplier<PositionReader>>) - Method in class alluxio.client.file.dora.DoraCacheClient
-
- createNewClassInstance(Class<T>, Class<?>[], Object[]) - Static method in class alluxio.util.CommonUtils
-
Creates new instance of a class by calling a constructor that receives ctorClassArgs arguments.
- createNewPath(String, boolean) - Method in class alluxio.uri.MultiPartSchemeURI
-
- createNewPath(String, boolean) - Method in class alluxio.uri.StandardURI
-
- createNewPath(String, boolean) - Method in interface alluxio.uri.URI
-
- createNewResource() - Method in class alluxio.client.block.BlockMasterClientPool
-
- createNewResource() - Method in class alluxio.client.block.stream.BlockWorkerClientPool
-
- createNewResource() - Method in class alluxio.client.file.FileSystemMasterClientPool
-
- createNewResource() - Method in class alluxio.client.job.JobMasterClientPool
-
- createNewResource() - Method in class alluxio.network.netty.NettyChannelPool
-
Creates a netty channel instance.
- createNewResource() - Method in class alluxio.resource.DynamicResourcePool
-
Creates a new resource.
- createNewResource() - Method in class alluxio.resource.ResourcePool
-
Creates a new resource which will be added to the resource pool after the user is done using
it.
- createNewResource() - Method in class alluxio.underfs.ByteBufferResourcePool
-
- createNewResource() - Method in class alluxio.worker.block.BlockMasterClientPool
-
- createNoAccess() - Static method in class alluxio.security.authorization.Mode
-
Creates the "no access" mode.
- createNonexistingFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- createNonexistingFile(String, CreateOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- createNonexistingFile(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
-
- createNonexistingFile(String, CreateOptions) - Method in class alluxio.underfs.ConsistentUnderFileSystem
-
- createNonexistingFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- createNonexistingFile(String, CreateOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- createNonexistingFile(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Creates a file in the under file system with the indicated name.
- createNonexistingFile(String, CreateOptions) - Method in interface alluxio.underfs.UnderFileSystem
-
Creates a file in the under file system with the specified
CreateOptions
.
- createNonexistingFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- createNonexistingFile(String, CreateOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class alluxio.hadoop.AbstractFileSystem
-
- createNoParentTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating file without parent.
- createObject(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- createObject(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- createObject(String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- createObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- createObject(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- createObject(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- createObject(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- createObjectOrUploadPart(String, String, String, String, S3Constants.Directive, String, S3Constants.Directive, String, String, String, String, Integer, String, String, String, InputStream) - Method in class alluxio.proxy.s3.S3RestServiceHandler
-
Uploads an object or part of an object in multipart upload.
- createOkResponse(DataBuffer) - Static method in class alluxio.network.protocol.RPCProtoMessage
-
Creates an OK response with data.
- createOpenAtPositionTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating file and opening at position.
- createOpenEmptyTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and opening empty file.
- createOpenExistingLargeFileTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and open existing large file.
- createOpenFilesLimitValidationTask() - Static method in class alluxio.cli.UserLimitValidationTask
-
Creates a validation task for checking whether the user limit for number of open files
is within reasonable range.
- createOpenLargeTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and opening large file.
- createOpenSkip() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for create file, open and seek.
- createOpenTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and opening file.
- CreateOptions - Class in alluxio.underfs.options
-
Method options for creating a file in UnderFileSystem.
- CreateOptions(String) - Constructor for class alluxio.underfs.options.CreateOptions
-
- createOrGetAppIdFromConfig(AlluxioConfiguration) - Static method in class alluxio.util.IdUtils
-
- createOrRefreshOssStsClient(UnderFileSystemConfiguration) - Method in class alluxio.underfs.oss.StsOssClientProvider
-
Create Or Refresh the STS OSS client.
- createPacketWriter(BlockWriteRequestContext, Channel) - Method in class alluxio.worker.netty.FileWriteHandler
-
- createPacketWriter(UfsFileWriteRequestContext, Channel) - Method in class alluxio.worker.netty.UfsFileWriteHandler
-
- createPageStoreDir(CacheEvictorOptions, PageStoreOptions) - Static method in interface alluxio.client.file.cache.store.PageStoreDir
-
Create an instance of PageStoreDir.
- createPageStoreDirs(CacheManagerOptions) - Static method in interface alluxio.client.file.cache.store.PageStoreDir
-
Create a list of PageStoreDir based on the configuration.
- createParentTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating file with parent.
- createPath(RpcContext, LockedInodePath, CreatePathContext<?, ?>) - Method in class alluxio.master.file.meta.InodeTree
-
Creates a file or directory at path.
- CreatePathContext<T extends com.google.protobuf.GeneratedMessageV3.Builder<?>,K extends CreatePathContext<?,?>> - Class in alluxio.master.file.contexts
-
- CreatePathContext(T) - Constructor for class alluxio.master.file.contexts.CreatePathContext
-
Creates context with given option data.
- createPathDepths(int) - Method in class alluxio.fsmaster.FileSystemMasterBase
-
- createProgressThread(PrintStream) - Static method in class alluxio.util.CommonUtils
-
- createProgressThread(long, PrintStream) - Static method in class alluxio.util.CommonUtils
-
Creates a thread which will write "." to the given print stream at the given interval.
- createRateLimiter(long) - Static method in class alluxio.proxy.s3.S3RestUtils
-
Create a rate limiter for given rate.
- createRateLimiter(long) - Static method in interface alluxio.util.RateLimiter
-
- createReader(CheckpointInputStream) - Method in interface alluxio.master.journal.checkpoint.CheckpointFormat
-
- createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.CompoundCheckpointFormat
-
- createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.InodeProtosCheckpointFormat
-
- createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.JournalCheckpointFormat
-
- createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.LongCheckpointFormat
-
- createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.LongsCheckpointFormat
-
- createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.TarballCheckpointFormat
-
- createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.ZipCheckpointFormat
-
- createReadRequest(Protocol.ReadRequest) - Method in class alluxio.worker.netty.AbstractReadHandler
-
- createReadRequest(Protocol.ReadRequest) - Method in class alluxio.worker.netty.FileReadHandler
-
- createRemoteGrpcDataServer(DataWorker) - Method in class alluxio.worker.DataServerFactory
-
- createRequestContext(ReadRequest) - Method in class alluxio.worker.grpc.FileReadHandler
-
- createRequestContext(WriteRequest) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
-
- createRequestContext(Protocol.WriteRequest) - Method in class alluxio.worker.netty.FileWriteHandler
-
- createRequestContext(Protocol.WriteRequest) - Method in class alluxio.worker.netty.UfsFileWriteHandler
-
- createResponse(AlluxioStatusException) - Static method in class alluxio.network.protocol.RPCProtoMessage
-
- createResponse(Status, String, DataBuffer) - Static method in class alluxio.network.protocol.RPCProtoMessage
-
Creates a response for a given status, message, and data buffer.
- createRpcContext() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- createRpcContext(OperationContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- createRpcExecutorService() - Method in class alluxio.master.AlluxioMasterProcess
-
- createRpcExecutorService() - Method in class alluxio.master.MasterProcess
-
- createRpcId() - Static method in class alluxio.util.IdUtils
-
- createSample(String, String, List<String>, List<String>, double) - Method in class alluxio.metrics.sink.RatisNameRewriteSampleBuilder
-
- createSaslClientHandler(AuthType, Subject, AlluxioConfiguration) - Method in class alluxio.grpc.GrpcChannel
-
- createSaslHandler(ChannelAuthenticationScheme) - Method in interface alluxio.security.authentication.AuthenticationServer
-
Creates server-side Sasl handler for given scheme.
- createSaslHandler(ChannelAuthenticationScheme) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
-
- createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class alluxio.security.authentication.plain.PlainSaslServer.Factory
-
Creates a
SaslServer
using the parameters supplied.
- createScope() - Method in class alluxio.s3.signature.AwsCredential
-
- createServerBuilder(String, SocketAddress, ChannelType) - Method in class alluxio.worker.grpc.GrpcDataServer
-
- createServerErrorResponseEvent(AlluxioStatusException) - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
-
Create a ServerErrorResponseEvent.
- createSessionId() - Static method in class alluxio.util.IdUtils
-
- createSignatureBase(SignatureInfo, ContainerRequestContext) - Static method in class alluxio.s3.signature.StringToSignProducer
-
Convert signature info to strToSign.
- createSignatureBase(SignatureInfo, HttpServletRequest) - Static method in class alluxio.s3.signature.StringToSignProducer
-
Convert signature info to strToSign.
- createSignatureBase(SignatureInfo, HttpRequest) - Static method in class alluxio.s3.signature.StringToSignProducer
-
Convert signature info to strToSign.
- createSignatureBase(SignatureInfo, String, String, String, Map<String, String>, Map<String, String>) - Static method in class alluxio.s3.signature.StringToSignProducer
-
Convert request info to strToSign.
- createStorageDirPath(String, String) - Static method in class alluxio.util.io.FileUtils
-
Creates the storage directory path, including any necessary but nonexistent parent directories.
- createStream(long, long) - Method in class alluxio.underfs.cos.COSInputStream
-
- createStream(long, long) - Method in class alluxio.underfs.MultiRangeObjectInputStream
-
Opens a new stream reading a range.
- createStream(long, long) - Method in class alluxio.underfs.obs.OBSInputStream
-
- createStream(long, long) - Method in class alluxio.underfs.oss.OSSInputStream
-
- createSyncLockingScheme(AlluxioURI, FileSystemMasterCommonPOptions, DescendantType) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- createTempBlockMeta(long, long, long) - Method in interface alluxio.worker.block.meta.DirView
-
Creates a
TempBlockMeta
given sessionId, blockId, and initialBlockSize.
- createThenDeleteExistingDirectoryTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and deleting existing directory.
- createThenGetExistingDirectoryStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting existing directory status.
- createThenGetExistingFileStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting existing file status.
- createThenGetExistingStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting existing status.
- createTimePredicate(String) - Method in class alluxio.master.predicate.TimePredicate.Factory
-
- createUfsBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockStore
-
Creates a block reader to read a UFS block starting from given block offset.
- createUfsBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
-
Creates a block reader to read a UFS block starting from given block offset.
- createUfsReadHeartBeatResponseEvent() - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
-
Create an UfsReadHeartBeatResponseEvent.
- createUnstartedStopwatch() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
-
- createUnstartedStopwatch() - Method in class alluxio.client.file.cache.LocalCachePositionReader
-
- createUnusedMountId() - Method in class alluxio.master.file.meta.MountTable
-
Creates a mount point ID and guarantees uniqueness.
- createUserProcessesLimitValidationTask() - Static method in class alluxio.cli.UserLimitValidationTask
-
Creates a validation task for checking whether the user limit for number of user processes
is within reasonable range.
- createWebServer() - Method in class alluxio.master.AlluxioJobMasterProcess
-
- createWebServer() - Method in class alluxio.master.AlluxioMasterProcess
-
- createWebServer() - Method in class alluxio.master.MasterProcess
-
- createWithRecorder(String, UnderFileSystemConfiguration, Recorder) - Static method in class alluxio.underfs.UnderFileSystem.Factory
-
Creates a client for operations involved with the under file system and record the
execution process.
- createWriteBatch() - Method in interface alluxio.master.metastore.InodeStore
-
Creates a write batch.
- createWriteBatch() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- createZkJobPrimarySelector() - Static method in class alluxio.master.PrimarySelector.Factory
-
- createZkPrimarySelector() - Static method in class alluxio.master.PrimarySelector.Factory
-
- CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
-
- CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
-
- CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
-
- CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
-
- CREATIONTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
-
- CREDENTIAL_FIELD_MASKER - Static variable in class alluxio.RpcSensitiveConfigMask
-
- CredentialPropertyKeys - Class in alluxio.conf
-
This class stores names of property keys whose values are credential.
- CredentialPropertyKeys() - Constructor for class alluxio.conf.CredentialPropertyKeys
-
- CronExpressionIntervalSupplier - Class in alluxio.heartbeat
-
Calculate the next interval by given cron expression.
- CronExpressionIntervalSupplier(CronExpression, long) - Constructor for class alluxio.heartbeat.CronExpressionIntervalSupplier
-
- CROSS_CLUSTER_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
-
CROSS_CLUSTER_MASTER_CLIENT_SERVICE = 1004;
- CSV_FILE_HEADER - Static variable in class alluxio.cli.docgen.ConfigurationDocGenerator
-
- CsvSink - Class in alluxio.metrics.sink
-
A sink which creates a CSV file of the metric values.
- CsvSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.CsvSink
-
- CuckooTable - Interface in alluxio.client.file.cache.cuckoofilter
-
The cuckoo table that supports to store and access data positioned by a specific bucket and slot.
- CuckooUtils - Class in alluxio.client.file.cache.cuckoofilter
-
This class provides some useful methods for cuckoo filters.
- CuckooUtils() - Constructor for class alluxio.client.file.cache.cuckoofilter.CuckooUtils
-
- CUR_DIR - Static variable in class alluxio.AlluxioURI
-
- CURRENT_VERSION_INFO - Static variable in class alluxio.RuntimeConstants
-
- CURRENTBLOCKS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
-
- CURRENTBLOCKSONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
-
- CurrentUser - Class in alluxio.security
-
This class represents the current user, which represents the end user.
- CurrentUser(String) - Constructor for class alluxio.security.CurrentUser
-
Constructs a new user with a name.
- CurrentUser(String, String) - Constructor for class alluxio.security.CurrentUser
-
Constructs a new user with a name and a service name.
- CUSTOM_EXCEPTION_MESSAGE - Static variable in exception alluxio.exception.BusyException
-
- CUSTOM_VALUE - Static variable in enum alluxio.grpc.ChannelAuthenticationScheme
-
CUSTOM = 2;
- CustomAuthenticationProvider - Class in alluxio.security.authentication.plain
-
An authentication provider implementation that allows
AuthenticationProvider
to be
customized at configuration time.
- CustomAuthenticationProvider(Class<?>) - Constructor for class alluxio.security.authentication.plain.CustomAuthenticationProvider
-
Constructs a new custom authentication provider.
- CustomAuthPolicy - Class in alluxio.fuse.auth
-
A Fuse authentication policy supports user-defined user and group.
- gainPrimacy() - Method in interface alluxio.master.journal.JournalSystem
-
Transitions the journal to primary mode.
- gainPrimacy() - Method in class alluxio.master.journal.noop.NoopJournalSystem
-
- gainPrimacy() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- gainPrimacy() - Method in class alluxio.master.journal.ufs.UfsJournal
-
Transitions the journal from standby to primary mode.
- gainPrimacy() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
-
- GarbageCollectorMXBeanView(GarbageCollectorMXBean) - Constructor for class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
-
- GAUGE_VALUE - Static variable in enum alluxio.grpc.MetricType
-
GAUGE is the simplest type of metric.
- GB - Static variable in class alluxio.Constants
-
- GCS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
-
- GCS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
-
- GCS_COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
-
- GCS_CREDENTIAL_PATH - Static variable in class alluxio.conf.PropertyKey
-
- GCS_CREDENTIAL_PATH - Static variable in class alluxio.conf.PropertyKey.Name
-
- GCS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
-
- GCS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
-
- GCSInputStream - Class in alluxio.underfs.gcs
-
A stream for reading a file from GCS.
- GCSOutputStream - Class in alluxio.underfs.gcs
-
A stream for writing a file into GCS.
- GCSOutputStream(String, String, GoogleStorageService, List<String>) - Constructor for class alluxio.underfs.gcs.GCSOutputStream
-
Constructs a new stream for writing a file.
- GCSPositionReader - Class in alluxio.underfs.gcs
-
- GCSPositionReader(GoogleStorageService, String, String, long) - Constructor for class alluxio.underfs.gcs.GCSPositionReader
-
- GCSUnderFileSystem - Class in alluxio.underfs.gcs
-
Google Cloud Storage
UnderFileSystem
implementation based on the jets3t library.
- GCSUnderFileSystem(AlluxioURI, GoogleStorageService, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.gcs.GCSUnderFileSystem
-
- GCSUnderFileSystemFactory - Class in alluxio.underfs.gcs
-
- GCSUnderFileSystemFactory() - Constructor for class alluxio.underfs.gcs.GCSUnderFileSystemFactory
-
- GCSUtils - Class in alluxio.underfs.gcs
-
Util functions for GCS under file system.
- GCSV2InputStream - Class in alluxio.underfs.gcs.v2
-
A stream for reading a file from GCS using Google cloud API (GCS input stream version 2).
- GCSV2OutputStream - Class in alluxio.underfs.gcs.v2
-
A stream for writing a file into GCS using Google cloud API (GCS output stream version 2).
- GCSV2OutputStream(String, String, Storage) - Constructor for class alluxio.underfs.gcs.v2.GCSV2OutputStream
-
Constructs a new stream for writing a file.
- GCSV2UnderFileSystem - Class in alluxio.underfs.gcs.v2
-
GCS FS
UnderFileSystem
implementation based on the Google cloud storage library.
- GCSV2UnderFileSystem(AlluxioURI, Storage, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- GeneralBenchSummary<T extends TaskResult> - Class in alluxio.stress.common
-
abstract class for BenchSummary.
- GeneralBenchSummary() - Constructor for class alluxio.stress.common.GeneralBenchSummary
-
- GeneralWorker(int, int, int, ByteBuffer, boolean, boolean, String) - Constructor for class alluxio.examples.Performance.GeneralWorker
-
- generate() - Static method in class alluxio.cli.docgen.ConfigurationDocGenerator
-
Generates the configuration docs.
- generate() - Static method in class alluxio.cli.docgen.MetricsDocGenerator
-
Writes the supported files for metrics system docs.
- generate(String[]) - Static method in class alluxio.cli.DocGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.client.ClientIOSummary.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.client.ClientIOTaskResult.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.worker.IOTaskSummary.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.worker.WorkerBenchSummary.GraphGenerator
-
- generateChildDirACL(Short) - Method in class alluxio.security.authorization.DefaultAccessControlList
-
Creates a child directory's access ACL and default ACL based on the default ACL.
- generateChildFileACL(Short) - Method in class alluxio.security.authorization.DefaultAccessControlList
-
create a child file 's accessACL based on the default ACL.
- generateClientFileInfo(String) - Method in class alluxio.master.file.meta.Inode
-
- generateClientFileInfo(String) - Method in interface alluxio.master.file.meta.InodeView
-
Generates a
FileInfo
of the file or folder.
- generateClientFileInfo(String) - Method in class alluxio.master.file.meta.MutableInode
-
- generateClientFileInfo(String) - Method in class alluxio.master.file.meta.MutableInodeDirectory
-
Generates client file info for a folder.
- generateClientFileInfo(String) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- generateClientWorkerInfo() - Method in class alluxio.job.MasterWorkerInfo
-
- generateJobConfig(String[]) - Method in class alluxio.stress.cli.Benchmark
-
- generateKey(AlluxioURI, UnderFileSystemConfiguration) - Method in class alluxio.underfs.AbstractUfsManager
-
- generateOrderedNodeInfos(Collection<WorkerInfo>) - Static method in class alluxio.util.webui.WebUtils
-
Order the nodes by hostName and generate
NodeInfo
list for UI display.
- generateOutputFile(String, String) - Method in class alluxio.cli.bundler.command.AbstractCollectInfoCommand
-
Generates the output file for the command to write printouts to.
- generateQueryString(Map<String, String>) - Static method in class alluxio.util.URIUtils
-
Generates a query string from a
Map
of key/value pairs.
- GenerateReport - Class in alluxio.stress.cli.report
-
Generates a report from summaries.
- GenerateReport() - Constructor for class alluxio.stress.cli.report.GenerateReport
-
Creates an instance.
- generateS3ErrorResponse(HttpResponseStatus, String, AsciiString) - Static method in class alluxio.s3.S3ErrorResponse
-
Generates standard S3 error http response.
- generateStateDiagram(Path) - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
-
Generates a diagram describing the state transition in a .dot file.
- generateStateDiagram(Path) - Method in class alluxio.worker.netty.NettyReadHandlerStateMachine
-
Generates a diagram describing the state transition in a .dot file.
- generateTestFilePaths(Path) - Method in class alluxio.stress.cli.worker.StressWorkerBench
-
Generates the target file paths in a deterministic manner.
- generateThreadName(String, String) - Static method in class alluxio.heartbeat.HeartbeatThread
-
- generateWorkerInfo(Set<GetWorkerReportOptions.WorkerInfoField>, WorkerState) - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
Gets the selected field information for this worker.
- get(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.CacheManager.Factory
-
- get(PageId, int, byte[], int) - Method in interface alluxio.client.file.cache.CacheManager
-
Reads the entire page if the queried page is found in the cache, stores the result in buffer.
- get(PageId, int, int, byte[], int) - Method in interface alluxio.client.file.cache.CacheManager
-
Reads a part of a page if the queried page is found in the cache, stores the result in buffer.
- get(PageId, int, ReadTargetBuffer, CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
-
Reads a part of a page if the queried page is found in the cache, stores the result in buffer.
- get(PageId, int, int, byte[], int, CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
-
Reads a part of a page if the queried page is found in the cache, stores the result in buffer.
- get(PageId, int, int, ReadTargetBuffer, CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
-
Reads a part of a page if the queried page is found in the cache, stores the result in buffer.
- get(PageId, int, int, ReadTargetBuffer, CacheContext) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- get(PageId, int, CacheScope) - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- get() - Static method in class alluxio.client.file.cache.context.CachePerThreadContext
-
- get(PageId, int, ReadTargetBuffer, CacheContext) - Method in class alluxio.client.file.cache.LocalCacheManager
-
- get(PageId, int, int, ReadTargetBuffer, CacheContext) - Method in class alluxio.client.file.cache.LocalCacheManager
-
- get(PageId, int, CacheScope) - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- get(PageId, int, ReadTargetBuffer, CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- get(PageId, int, byte[], int) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- get(PageId, int, int, byte[], int) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- get(PageId, int, int, byte[], int, CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- get(PageId, int, int, ReadTargetBuffer, CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- get(PageId, ReadTargetBuffer) - Method in interface alluxio.client.file.cache.PageStore
-
Gets a page from the store to the destination buffer.
- get(PageId, int, int, ReadTargetBuffer) - Method in interface alluxio.client.file.cache.PageStore
-
Gets part of a page from the store to the destination buffer.
- get(PageId, int, int, ReadTargetBuffer, boolean) - Method in interface alluxio.client.file.cache.PageStore
-
Gets part of a page from the store to the destination buffer.
- get(PageId, int, CacheScope) - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
Reads the entire page and refresh its access time if the queried page is found in the cache.
- get(PageId, int, int, ReadTargetBuffer, boolean) - Method in class alluxio.client.file.cache.store.LocalPageStore
-
- get(PageId, int, int, ReadTargetBuffer, boolean) - Method in class alluxio.client.file.cache.store.MemoryPageStore
-
- get(PageId, int, int, ReadTargetBuffer, boolean) - Method in class alluxio.client.file.cache.TimeBoundPageStore
-
- get() - Static method in class alluxio.client.file.FileSystem.Factory
-
- get(Subject) - Static method in class alluxio.client.file.FileSystem.Factory
-
Get a FileSystem from the cache with a given subject.
- get(Subject, AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystem.Factory
-
Get a FileSystem from the cache with a given subject.
- get(FileSystemCache.Key) - Method in class alluxio.client.file.FileSystemCache
-
- get(AlluxioURI) - Method in class alluxio.client.file.MetadataCache
-
- get() - Method in class alluxio.CloseableSupplier
-
- get(int) - Method in interface alluxio.collections.BitSet
-
- get(int) - Method in class alluxio.collections.BuiltinBitSet
-
- get(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
-
- get(K, LockMode) - Method in class alluxio.collections.LockPool
-
Locks the specified key in the specified mode.
- get(K, LockMode, boolean) - Method in class alluxio.collections.LockPool
-
Locks the specified key in the specified mode.
- get(int) - Method in class alluxio.collections.UnmodifiableArrayList
-
- get() - Method in class alluxio.concurrent.jsr.CompletableFuture
-
Waits if necessary for this future to complete, and then returns its result.
- get(long, TimeUnit) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
Waits if necessary for at most the given time for this future to complete, and then returns its
result, if available.
- get() - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Waits if necessary for the computation to complete, and then retrieves its result.
- get(long, TimeUnit) - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Waits if necessary for at most the given time for the computation to complete, and then
retrieves its result, if available.
- get(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the value for the given key in the
Properties
; if this key is not found, a
RuntimeException is thrown.
- get(PropertyKey, ConfigurationValueOptions) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the value for the given key in the
Properties
; if this key is not found, a
RuntimeException is thrown.
- get(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
-
- get(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the value for the given key in the
Properties
; if this key is not found, a
RuntimeException is thrown.
- get(PropertyKey, ConfigurationValueOptions) - Static method in class alluxio.conf.Configuration
-
Gets the value for the given key in the
Properties
; if this key is not found, a
RuntimeException is thrown.
- get() - Method in class alluxio.conf.Hash
-
If
Hash.markOutdated()
is called since last
Hash.get()
, then the version will be
recomputed, otherwise, the internally cached version is returned.
- get(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- get(PropertyKey, ConfigurationValueOptions) - Method in class alluxio.conf.InstancedConfiguration
-
- get() - Method in class alluxio.DefaultSupplier
-
- get() - Method in class alluxio.fuse.AlluxioFuseUtils.CloseableFuseFileInfo
-
- get(long, byte[]) - Method in class alluxio.inode.RocksBenchBase
-
- get(long) - Method in class alluxio.job.util.TimeSeries
-
- get(int) - Method in class alluxio.master.file.meta.CompositeInodeLockList
-
- get(int) - Method in interface alluxio.master.file.meta.InodeLockList
-
- get(long) - Method in class alluxio.master.file.meta.LazyUfsBlockLocationCache
-
- get(long, AlluxioURI, long) - Method in class alluxio.master.file.meta.LazyUfsBlockLocationCache
-
- get(int) - Method in class alluxio.master.file.meta.SimpleInodeLockList
-
- get(long) - Method in interface alluxio.master.file.meta.UfsBlockLocationCache
-
- get(long, AlluxioURI, long) - Method in interface alluxio.master.file.meta.UfsBlockLocationCache
-
If the locations exist in the cache, return them, otherwise, retrieves the block locations
from UFS, and caches the result.
- get() - Method in class alluxio.master.file.RpcContext
-
- get() - Method in interface alluxio.master.journal.JournalContext
-
- get() - Method in class alluxio.master.meta.PathProperties
-
- get(K, ReadOption) - Method in class alluxio.master.metastore.caching.Cache
-
Retrieves a value from the cache, loading it from the backing store if necessary.
- get(K) - Method in class alluxio.master.metastore.caching.Cache
-
- get(long, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- get(long, ReadOption) - Method in interface alluxio.master.metastore.InodeStore
-
- get(long, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- get(long) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- get() - Method in class alluxio.master.predicate.DatePredicate
-
- get() - Method in interface alluxio.master.predicate.FilePredicate
-
Get the predicate function from the file predicate.
- get() - Method in class alluxio.master.predicate.TimePredicate
-
- get(AlluxioConfiguration) - Static method in class alluxio.membership.MembershipManager.Factory
-
Get or create a MembershipManager instance.
- get(Class<W>) - Method in class alluxio.Registry
-
- get(Class<W>, int) - Method in class alluxio.Registry
-
Attempts to look up the
Server
for the given class.
- get() - Method in class alluxio.resource.CloseableResource
-
- get(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
-
- get(AlluxioConfiguration) - Static method in class alluxio.security.group.GroupMappingService.Factory
-
Gets the cached groups mapping service being used to map user-to-groups.
- get(AlluxioURI, UnderFileSystemConfiguration) - Method in class alluxio.underfs.AbstractUfsManager
-
Gets an instance for the given UFS URI and configuration, if such exists.
- get(AbstractUfsManager.Key) - Method in class alluxio.underfs.AbstractUfsManager
-
- get(long) - Method in class alluxio.underfs.AbstractUfsManager
-
- get(long) - Method in class alluxio.underfs.JobUfsManager
-
- get(long) - Method in interface alluxio.underfs.UfsManager
-
Gets UFS information from the manager if this mount ID exists, or throws exception otherwise.
- get(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- get(PropertyKey, ConfigurationValueOptions) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- get(long) - Method in class alluxio.underfs.WorkerUfsManager
-
Gets UFS information from the manager if this mount ID exists, or throws exception otherwise.
- get(String, Integer, HttpUtils.IProcessInputStream) - Static method in class alluxio.util.network.HttpUtils
-
Uses the get method to send a url with arguments by http, this method can call RESTful Api.
- get(String, Integer) - Static method in class alluxio.util.network.HttpUtils
-
Uses the get method to send a url with arguments by http, this method can call RESTful Api.
- get() - Method in class alluxio.worker.modules.WorkerIdentityProvider
-
Resolves a worker's identity from the following sources, in the order of preference:
Alluxio configuration.
- GET_INFO - Static variable in class alluxio.master.AlluxioJobMasterRestServiceHandler
-
- GET_INFO - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
- GET_INFO - Static variable in class alluxio.proxy.AlluxioProxyRestServiceHandler
-
- GET_INFO - Static variable in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
-
- GET_STATUS - Static variable in class alluxio.job.ServiceConstants
-
- GET_STATUS - Static variable in class alluxio.proxy.PathsRestServiceHandler
-
- getAbsolutePath() - Method in class alluxio.util.webui.UIFileInfo
-
Gets absolute path.
- getAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAcl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAclBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAclOrBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAclOrBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAclOrBuilder() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessControlException() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets access control exception.
- getAccessID() - Method in class alluxio.s3.auth.AwsAuthInfo
-
- getAccessKeyID() - Method in class alluxio.s3.signature.AwsCredential
-
- getAccessMode() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.Bits accessMode = 3;
- getAccessMode() - Method in class alluxio.grpc.GetStatusPOptions
-
optional .alluxio.grpc.Bits accessMode = 3;
- getAccessMode() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional .alluxio.grpc.Bits accessMode = 3;
- getAcl() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getAcl() - Method in class alluxio.client.file.URIStatus
-
- getAcl() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl acl = 27;
- getAcl() - Method in class alluxio.grpc.FileInfo
-
optional .alluxio.grpc.file.PAcl acl = 27;
- getAcl() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional .alluxio.grpc.file.PAcl acl = 27;
- getAcl() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getACL() - Method in class alluxio.master.file.meta.Inode
-
- getACL() - Method in interface alluxio.master.file.meta.InodeView
-
- getACL() - Method in class alluxio.master.file.meta.MutableInode
-
- getAcl() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- getAcl() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- getAcl() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- getAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- getAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- getAcl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- getAcl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- getAcl() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- getAcl() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- getAcl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- getAcl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- getAcl() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- getAcl(FileSystem, String) - Method in class alluxio.underfs.hdfs.acl.SupportedHdfsAclProvider
-
- getAcl(FileSystem, String) - Method in interface alluxio.underfs.hdfs.HdfsAclProvider
-
- getAcl(FileSystem, String) - Method in class alluxio.underfs.hdfs.NoopHdfsAclProvider
-
- getAcl() - Method in class alluxio.underfs.options.CreateOptions
-
- getAcl() - Method in class alluxio.wire.FileInfo
-
- getAclBuilder() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl acl = 27;
- getAclBuilder() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- getAclBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- getAclBuilder() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- getAclBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- getAclOrBuilder() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl acl = 27;
- getAclOrBuilder() - Method in class alluxio.grpc.FileInfo
-
optional .alluxio.grpc.file.PAcl acl = 27;
- getAclOrBuilder() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional .alluxio.grpc.file.PAcl acl = 27;
- getAclOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- getAclOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- getAclOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- getAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- getAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- getAclOrBuilder() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- getAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- getAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- getAclOrBuilder() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- getAclOrBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- getAclOrBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- getAclOrBuilder() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- getAclPair(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getAclPair(String) - Method in class alluxio.underfs.BaseUnderFileSystem
-
- getAclPair(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getAclPair(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the ACL and the Default ACL of a file or directory in under file system.
- getAclPair(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getAction() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the set action to perform
- getAction() - Method in class alluxio.grpc.SetAclPRequest
-
the set action to perform
- getAction() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the set action to perform
- getAction() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional .alluxio.proto.journal.PSetAclAction action = 3;
- getAction() - Method in class alluxio.proto.journal.File.SetAclEntry
-
optional .alluxio.proto.journal.PSetAclAction action = 3;
- getAction() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
optional .alluxio.proto.journal.PSetAclAction action = 3;
- getActionId() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionId = 1;
- getActionId() - Method in class alluxio.grpc.ActionInfo
-
optional string actionId = 1;
- getActionId() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string actionId = 1;
- getActionId() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string actionId = 2;
- getActionId() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional string actionId = 2;
- getActionId() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional string actionId = 2;
- getActionIdBytes() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionId = 1;
- getActionIdBytes() - Method in class alluxio.grpc.ActionInfo
-
optional string actionId = 1;
- getActionIdBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string actionId = 1;
- getActionIdBytes() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string actionId = 2;
- getActionIdBytes() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional string actionId = 2;
- getActionIdBytes() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional string actionId = 2;
- getActionInfo(GetActionInfoRequest, StreamObserver<GetActionInfoResponse>) - Method in interface alluxio.grpc.PolicyMasterClientServiceGrpc.AsyncService
-
Gets the information of a action
- getActionInfo(GetActionInfoRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceBlockingStub
-
Gets the information of a action
- getActionInfo(GetActionInfoRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceFutureStub
-
Gets the information of a action
- getActionInfo(GetActionInfoRequest, StreamObserver<GetActionInfoResponse>) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceStub
-
Gets the information of a action
- GetActionInfoOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetActionInfoOptions
- GetActionInfoOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetActionInfoOptions
- GetActionInfoOptionsOrBuilder - Interface in alluxio.grpc
-
- GetActionInfoRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetActionInfoRequest
- GetActionInfoRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetActionInfoRequest
- GetActionInfoRequestOrBuilder - Interface in alluxio.grpc
-
- GetActionInfoResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetActionInfoResponse
- GetActionInfoResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetActionInfoResponse
- GetActionInfoResponseOrBuilder - Interface in alluxio.grpc
-
- getActions(int) - Method in class alluxio.grpc.PAclEntry.Builder
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- getActions(int) - Method in class alluxio.grpc.PAclEntry
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- getActions(int) - Method in interface alluxio.grpc.PAclEntryOrBuilder
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- getActions(int) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- getActions(int) - Method in class alluxio.proto.shared.Acl.AclActions
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- getActions(int) - Method in interface alluxio.proto.shared.Acl.AclActionsOrBuilder
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- getActions(int) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- getActions(int) - Method in class alluxio.proto.shared.Acl.AclEntry
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- getActions(int) - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- getActions() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional .alluxio.proto.shared.AclActions actions = 2;
- getActions() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
optional .alluxio.proto.shared.AclActions actions = 2;
- getActions() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
-
optional .alluxio.proto.shared.AclActions actions = 2;
- getActions() - Method in class alluxio.security.authorization.AclActions
-
- getActions() - Method in class alluxio.security.authorization.AclEntry
-
- getActionsBuilder() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional .alluxio.proto.shared.AclActions actions = 2;
- getActionsCanceled() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsCanceled = 8;
- getActionsCanceled() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 actionsCanceled = 8;
- getActionsCanceled() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 actionsCanceled = 8;
- getActionsCount() - Method in class alluxio.grpc.PAclEntry.Builder
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- getActionsCount() - Method in class alluxio.grpc.PAclEntry
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- getActionsCount() - Method in interface alluxio.grpc.PAclEntryOrBuilder
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- getActionsCount() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- getActionsCount() - Method in class alluxio.proto.shared.Acl.AclActions
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- getActionsCount() - Method in interface alluxio.proto.shared.Acl.AclActionsOrBuilder
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- getActionsCount() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- getActionsCount() - Method in class alluxio.proto.shared.Acl.AclEntry
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- getActionsCount() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- getActionsFailed() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsFailed = 9;
- getActionsFailed() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 actionsFailed = 9;
- getActionsFailed() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 actionsFailed = 9;
- getActionsList() - Method in class alluxio.grpc.PAclEntry.Builder
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- getActionsList() - Method in class alluxio.grpc.PAclEntry
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- getActionsList() - Method in interface alluxio.grpc.PAclEntryOrBuilder
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- getActionsList() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- getActionsList() - Method in class alluxio.proto.shared.Acl.AclActions
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- getActionsList() - Method in interface alluxio.proto.shared.Acl.AclActionsOrBuilder
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- getActionsList() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- getActionsList() - Method in class alluxio.proto.shared.Acl.AclEntry
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- getActionsList() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- getActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional .alluxio.proto.shared.AclActions actions = 2;
- getActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
optional .alluxio.proto.shared.AclActions actions = 2;
- getActionsOrBuilder() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
-
optional .alluxio.proto.shared.AclActions actions = 2;
- getActionsRunning() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsRunning = 6;
- getActionsRunning() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 actionsRunning = 6;
- getActionsRunning() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 actionsRunning = 6;
- getActionsScheduled() - Method in class alluxio.grpc.PolicyStatus.Builder
-
metrics
- getActionsScheduled() - Method in class alluxio.grpc.PolicyStatus
-
metrics
- getActionsScheduled() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
metrics
- getActionsSucceeded() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsSucceeded = 7;
- getActionsSucceeded() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 actionsSucceeded = 7;
- getActionsSucceeded() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 actionsSucceeded = 7;
- getActionStatus() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionStatus = 3;
- getActionStatus() - Method in class alluxio.grpc.ActionInfo
-
optional string actionStatus = 3;
- getActionStatus() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string actionStatus = 3;
- getActionStatusBytes() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionStatus = 3;
- getActionStatusBytes() - Method in class alluxio.grpc.ActionInfo
-
optional string actionStatus = 3;
- getActionStatusBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string actionStatus = 3;
- getActionType() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionType = 2;
- getActionType() - Method in class alluxio.grpc.ActionInfo
-
optional string actionType = 2;
- getActionType() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string actionType = 2;
- getActionTypeBytes() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionType = 2;
- getActionTypeBytes() - Method in class alluxio.grpc.ActionInfo
-
optional string actionType = 2;
- getActionTypeBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string actionType = 2;
- getActiveCount() - Method in class alluxio.master.AlluxioExecutorService
-
- getActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
action fields.
- getActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
action fields.
- getActiveSyncTxId() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
action fields.
- getActiveSyncTxIdBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
action fields.
- getActiveSyncTxIdOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
action fields.
- getActiveSyncTxIdOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
action fields.
- getActiveSyncTxIdOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
action fields.
- getActiveThreadCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns an estimate of the number of threads that are currently stealing or executing tasks.
- getActiveWorkers() - Method in class alluxio.master.scheduler.Scheduler
-
Get active workers.
- getAddedBlocks(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocks(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocks(int) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocks() - Method in class alluxio.worker.block.BlockHeartbeatReport
-
Gets the list of blocks added by the worker in the heartbeat this report represents.
- getAddedBlocksBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksCount() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksList() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksList() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksList() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
Deprecated.
- getAddedBlocksOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
Deprecated.
- getAddedBlocksOnTiers() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
Deprecated.
- getAddedBlocksOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- getAddedBlocksOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
- getAddedBlocksOnTiersCount() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- getAddedBlocksOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- getAddedBlocksOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- getAddedBlocksOnTiersMap() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- getAddedBlocksOnTiersOrDefault(String, TierList) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- getAddedBlocksOnTiersOrDefault(String, TierList) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- getAddedBlocksOnTiersOrDefault(String, TierList) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- getAddedBlocksOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- getAddedBlocksOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- getAddedBlocksOnTiersOrThrow(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
- getAddedBlocksOrBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksOrBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksOrBuilder(int) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksOrBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksOrBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddedBlocksOrBuilderList() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- getAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- getAddMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- getAddMountPointBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- getAddMountPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- getAddMountPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- getAddMountPointOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- getAddPolicyMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
-
- getAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequestBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequestOrBuilder() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddress() - Method in class alluxio.client.block.stream.BlockWorkerClientPool
-
- getAddress() - Method in class alluxio.grpc.GrpcChannelBuilder
-
- getAddress() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.NetAddress address = 1;
- getAddress() - Method in class alluxio.grpc.ProxyStatus
-
optional .alluxio.grpc.NetAddress address = 1;
- getAddress() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional .alluxio.grpc.NetAddress address = 1;
- getAddress() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- getAddress() - Method in class alluxio.grpc.WorkerInfo
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- getAddress() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- getAddress() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- getAddress() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- getAddress() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- getAddress() - Method in class alluxio.master.LocalAlluxioMaster
-
- getAddress() - Method in class alluxio.master.meta.JobMasterInfo
-
- getAddress() - Method in class alluxio.master.meta.MasterInfo
-
- getAddress() - Method in class alluxio.master.meta.ProxyInfo
-
- getAddress() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
-
- getAddress() - Method in class alluxio.util.webui.UIMasterInfo
-
Gets master address.
- getAddress() - Method in class alluxio.wire.MasterInfo
-
- getAddress() - Method in class alluxio.wire.WorkerInfo
-
- getAddress() - Method in class alluxio.worker.AlluxioJobWorkerProcess
-
- getAddress() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getAddress() - Method in interface alluxio.worker.dora.DoraWorker
-
Get the address of the Dora Worker.
- getAddress() - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getAddress() - Method in interface alluxio.worker.JobWorkerProcess
-
- getAddress() - Method in interface alluxio.worker.WorkerProcess
-
- getAddressBuilder() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.NetAddress address = 1;
- getAddressBuilder() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- getAddressBuilder() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- getAddresses() - Method in class alluxio.client.block.options.GetWorkerReportOptions
-
- getAddresses(int) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
addresses are only valid when workerRange is SPECIFIED
- getAddresses(int) - Method in class alluxio.grpc.GetWorkerReportPOptions
-
addresses are only valid when workerRange is SPECIFIED
- getAddresses(int) - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
-
addresses are only valid when workerRange is SPECIFIED
- getAddresses() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional .alluxio.grpc.NetAddress addresses = 1;
- getAddresses() - Method in class alluxio.grpc.MasterVersion
-
optional .alluxio.grpc.NetAddress addresses = 1;
- getAddresses() - Method in interface alluxio.grpc.MasterVersionOrBuilder
-
optional .alluxio.grpc.NetAddress addresses = 1;
- getAddresses() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
-
- getAddressesBuilder() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional .alluxio.grpc.NetAddress addresses = 1;
- getAddressesBytes(int) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
addresses are only valid when workerRange is SPECIFIED
- getAddressesBytes(int) - Method in class alluxio.grpc.GetWorkerReportPOptions
-
addresses are only valid when workerRange is SPECIFIED
- getAddressesBytes(int) - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
-
addresses are only valid when workerRange is SPECIFIED
- getAddressesCount() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
addresses are only valid when workerRange is SPECIFIED
- getAddressesCount() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
addresses are only valid when workerRange is SPECIFIED
- getAddressesCount() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
-
addresses are only valid when workerRange is SPECIFIED
- getAddressesList() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
addresses are only valid when workerRange is SPECIFIED
- getAddressesList() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
addresses are only valid when workerRange is SPECIFIED
- getAddressesList() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
-
addresses are only valid when workerRange is SPECIFIED
- getAddressesOrBuilder() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional .alluxio.grpc.NetAddress addresses = 1;
- getAddressesOrBuilder() - Method in class alluxio.grpc.MasterVersion
-
optional .alluxio.grpc.NetAddress addresses = 1;
- getAddressesOrBuilder() - Method in interface alluxio.grpc.MasterVersionOrBuilder
-
optional .alluxio.grpc.NetAddress addresses = 1;
- getAddressOrBuilder() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.NetAddress address = 1;
- getAddressOrBuilder() - Method in class alluxio.grpc.ProxyStatus
-
optional .alluxio.grpc.NetAddress address = 1;
- getAddressOrBuilder() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional .alluxio.grpc.NetAddress address = 1;
- getAddressOrBuilder() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- getAddressOrBuilder() - Method in class alluxio.grpc.WorkerInfo
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- getAddressOrBuilder() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- getAddressOrBuilder() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- getAddressOrBuilder() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- getAddressOrBuilder() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- getAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- getAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- getAddSyncPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- getAddSyncPointBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- getAddSyncPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- getAddSyncPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- getAddSyncPointOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- getAdvice() - Method in class alluxio.cli.ValidationTaskResult
-
- getAffectedPaths(int) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- getAffectedPaths(int) - Method in class alluxio.grpc.JobInfo
-
repeated string affectedPaths = 14;
- getAffectedPaths(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated string affectedPaths = 14;
- getAffectedPaths() - Method in interface alluxio.job.wire.JobInfo
-
- getAffectedPaths() - Method in class alluxio.job.wire.PlanInfo
-
- getAffectedPathsBytes(int) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- getAffectedPathsBytes(int) - Method in class alluxio.grpc.JobInfo
-
repeated string affectedPaths = 14;
- getAffectedPathsBytes(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated string affectedPaths = 14;
- getAffectedPathsCount() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- getAffectedPathsCount() - Method in class alluxio.grpc.JobInfo
-
repeated string affectedPaths = 14;
- getAffectedPathsCount() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated string affectedPaths = 14;
- getAffectedPathsList() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- getAffectedPathsList() - Method in class alluxio.grpc.JobInfo
-
repeated string affectedPaths = 14;
- getAffectedPathsList() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated string affectedPaths = 14;
- getAge(T) - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
Get the item's clock value (age).
- getAlgorithm() - Method in class alluxio.s3.signature.SignatureInfo
-
- getAlias(int) - Method in class alluxio.DefaultStorageTierAssoc
-
- getAlias(int) - Method in interface alluxio.StorageTierAssoc
-
- getAliases() - Method in class alluxio.conf.PropertyKey
-
- getAll() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
optional bool all = 1;
- getAll() - Method in class alluxio.grpc.table.AllOrNoneSet
-
optional bool all = 1;
- getAll() - Method in interface alluxio.grpc.table.AllOrNoneSetOrBuilder
-
optional bool all = 1;
- getAllDatabases() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getAllDatabases() - Method in interface alluxio.client.table.TableMasterClient
-
Get a list of all database names.
- getAllDatabases(GetAllDatabasesPRequest, StreamObserver<GetAllDatabasesPResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
-
Returns all databases in the catalog
- getAllDatabases(GetAllDatabasesPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
-
Returns all databases in the catalog
- getAllDatabases(GetAllDatabasesPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
-
Returns all databases in the catalog
- getAllDatabases(GetAllDatabasesPRequest, StreamObserver<GetAllDatabasesPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
-
Returns all databases in the catalog
- GetAllDatabasesPRequest - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetAllDatabasesPRequest
- GetAllDatabasesPRequest.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetAllDatabasesPRequest
- GetAllDatabasesPRequestOrBuilder - Interface in alluxio.grpc.table
-
- GetAllDatabasesPResponse - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetAllDatabasesPResponse
- GetAllDatabasesPResponse.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetAllDatabasesPResponse
- GetAllDatabasesPResponseOrBuilder - Interface in alluxio.grpc.table
-
- getAllFailedPaths() - Method in class alluxio.master.job.JobMaster
-
- getAllInfo() - Method in class alluxio.master.job.workflow.WorkflowTracker
-
- getAllInTopologicalOrder() - Method in class alluxio.collections.DirectedAcyclicGraph
-
Gets all payloads of the DAG in the topological order.
- getAllJobMasterStatus() - Method in class alluxio.master.job.JobMaster
-
Lists the status of all job masters in the cluster.
- getAllLiveServices() - Method in class alluxio.membership.ServiceDiscoveryRecipe
-
Get all healthy service list.
- getAllMasterStatus() - Method in interface alluxio.client.job.JobMasterClient
-
Gets the status of all job masters in the cluster.
- getAllMasterStatus() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- getAllMasterStatus(GetAllMasterStatusPRequest, StreamObserver<GetAllMasterStatusPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
-
Lists all job master status.
- getAllMasterStatus(GetAllMasterStatusPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
-
Lists all job master status.
- getAllMasterStatus(GetAllMasterStatusPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
-
Lists all job master status.
- getAllMasterStatus(GetAllMasterStatusPRequest, StreamObserver<GetAllMasterStatusPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
-
Lists all job master status.
- getAllMasterStatus(GetAllMasterStatusPRequest, StreamObserver<GetAllMasterStatusPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
-
- GetAllMasterStatusPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllMasterStatusPOptions
- GetAllMasterStatusPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllMasterStatusPOptions
- GetAllMasterStatusPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetAllMasterStatusPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllMasterStatusPRequest
- GetAllMasterStatusPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllMasterStatusPRequest
- GetAllMasterStatusPRequestOrBuilder - Interface in alluxio.grpc
-
- GetAllMasterStatusPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllMasterStatusPResponse
- GetAllMasterStatusPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllMasterStatusPResponse
- GetAllMasterStatusPResponseOrBuilder - Interface in alluxio.grpc
-
- getAllMembers() - Method in class alluxio.membership.EtcdMembershipManager
-
- getAllMembers() - Method in class alluxio.membership.MasterMembershipManager
-
- getAllMembers() - Method in interface alluxio.membership.MembershipManager
-
Get all registered worker members.
- getAllMembers() - Method in class alluxio.membership.StaticMembershipManager
-
- getAllOrNone() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNone() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNone() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNoneBuilder() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNoneOrBuilder() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNoneOrBuilder() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNoneOrBuilder() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllowed() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional bool allowed = 2;
- getAllowed() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
optional bool allowed = 2;
- getAllowed() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
-
optional bool allowed = 2;
- getAllowedOnStandbyMasters() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
optional bool allowedOnStandbyMasters = 2;
- getAllowedOnStandbyMasters() - Method in class alluxio.grpc.GetServiceVersionPRequest
-
optional bool allowedOnStandbyMasters = 2;
- getAllowedOnStandbyMasters() - Method in interface alluxio.grpc.GetServiceVersionPRequestOrBuilder
-
optional bool allowedOnStandbyMasters = 2;
- getAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool allowExists = 2;
- getAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional bool allowExists = 2;
- getAllowExists() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional bool allowExists = 2;
- getAllowLeader() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool allowLeader = 3;
- getAllowLeader() - Method in class alluxio.grpc.BackupPOptions
-
optional bool allowLeader = 3;
- getAllowLeader() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
-
optional bool allowLeader = 3;
- getAllPagesByFileId(String) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
-
- getAllPagesByFileId(String) - Method in interface alluxio.client.file.cache.PageMetaStore
-
Gets all pages by the specified File ID.
- getAllTables(String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getAllTables(String) - Method in interface alluxio.client.table.TableMasterClient
-
Get a list of all table names.
- getAllTables(GetAllTablesPRequest, StreamObserver<GetAllTablesPResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
-
Returns all tables in the database
- getAllTables(GetAllTablesPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
-
Returns all tables in the database
- getAllTables(GetAllTablesPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
-
Returns all tables in the database
- getAllTables(GetAllTablesPRequest, StreamObserver<GetAllTablesPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
-
Returns all tables in the database
- GetAllTablesPRequest - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetAllTablesPRequest
- GetAllTablesPRequest.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetAllTablesPRequest
- GetAllTablesPRequestOrBuilder - Interface in alluxio.grpc.table
-
- GetAllTablesPResponse - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetAllTablesPResponse
- GetAllTablesPResponse.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetAllTablesPResponse
- GetAllTablesPResponseOrBuilder - Interface in alluxio.grpc.table
-
- getAllThroughput() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- getAllTransformJobInfo() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getAllTransformJobInfo() - Method in interface alluxio.client.table.TableMasterClient
-
- getAlluxioFileName(String) - Static method in class alluxio.hadoop.HadoopUtils
-
Given a String
path, returns an equivalent Alluxio path.
- getAlluxioFuseSpecificMountOptionKeys() - Method in class alluxio.fuse.options.MountOptions
-
A set recognized option keys.
- getAlluxioHome() - Method in class alluxio.master.LocalAlluxioCluster
-
- getAlluxioOnly() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool alluxioOnly = 2;
- getAlluxioOnly() - Method in class alluxio.grpc.DeletePOptions
-
optional bool alluxioOnly = 2;
- getAlluxioOnly() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional bool alluxioOnly = 2;
- getAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
Deprecated, this field is about whether to delete in the UFS.
- getAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
Deprecated, this field is about whether to delete in the UFS.
- getAlluxioOnly() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
Deprecated, this field is about whether to delete in the UFS.
- getAlluxioOptions() - Method in class alluxio.fuse.options.MountOptions
-
- getAlluxioPath() - Method in class alluxio.grpc.File.Builder
-
optional string alluxio_path = 1;
- getAlluxioPath() - Method in class alluxio.grpc.File
-
optional string alluxio_path = 1;
- getAlluxioPath() - Method in interface alluxio.grpc.FileOrBuilder
-
optional string alluxio_path = 1;
- getAlluxioPath() - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of alluxio mount point
- getAlluxioPath() - Method in class alluxio.grpc.MountPRequest
-
the path of alluxio mount point
- getAlluxioPath() - Method in interface alluxio.grpc.MountPRequestOrBuilder
-
the path of alluxio mount point
- getAlluxioPath() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
optional string alluxioPath = 1;
- getAlluxioPath() - Method in class alluxio.grpc.ReverseResolvePResponse
-
optional string alluxioPath = 1;
- getAlluxioPath() - Method in interface alluxio.grpc.ReverseResolvePResponseOrBuilder
-
optional string alluxioPath = 1;
- getAlluxioPath() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
the path of the alluxio mount point
- getAlluxioPath() - Method in class alluxio.grpc.UnmountPRequest
-
the path of the alluxio mount point
- getAlluxioPath() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
-
the path of the alluxio mount point
- getAlluxioPath() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
the path of alluxio mount point
- getAlluxioPath() - Method in class alluxio.grpc.UpdateMountPRequest
-
the path of alluxio mount point
- getAlluxioPath() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
-
the path of alluxio mount point
- getAlluxioPath(Path) - Method in class alluxio.hadoop.AbstractFileSystem
-
Used to convert hadoop path to Alluxio path.
- getAlluxioPath(Path) - Method in class alluxio.hadoop.FileSystem
-
- getAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string alluxio_path = 1;
- getAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional string alluxio_path = 1;
- getAlluxioPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional string alluxio_path = 1;
- getAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
optional string alluxio_path = 1;
- getAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
-
optional string alluxio_path = 1;
- getAlluxioPath() - Method in interface alluxio.proto.journal.File.DeleteMountPointEntryOrBuilder
-
optional string alluxio_path = 1;
- getAlluxioPath() - Method in class alluxio.worker.block.CreateBlockOptions
-
- getAlluxioPathBytes() - Method in class alluxio.grpc.File.Builder
-
optional string alluxio_path = 1;
- getAlluxioPathBytes() - Method in class alluxio.grpc.File
-
optional string alluxio_path = 1;
- getAlluxioPathBytes() - Method in interface alluxio.grpc.FileOrBuilder
-
optional string alluxio_path = 1;
- getAlluxioPathBytes() - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of alluxio mount point
- getAlluxioPathBytes() - Method in class alluxio.grpc.MountPRequest
-
the path of alluxio mount point
- getAlluxioPathBytes() - Method in interface alluxio.grpc.MountPRequestOrBuilder
-
the path of alluxio mount point
- getAlluxioPathBytes() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
optional string alluxioPath = 1;
- getAlluxioPathBytes() - Method in class alluxio.grpc.ReverseResolvePResponse
-
optional string alluxioPath = 1;
- getAlluxioPathBytes() - Method in interface alluxio.grpc.ReverseResolvePResponseOrBuilder
-
optional string alluxioPath = 1;
- getAlluxioPathBytes() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
the path of the alluxio mount point
- getAlluxioPathBytes() - Method in class alluxio.grpc.UnmountPRequest
-
the path of the alluxio mount point
- getAlluxioPathBytes() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
-
the path of the alluxio mount point
- getAlluxioPathBytes() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
the path of alluxio mount point
- getAlluxioPathBytes() - Method in class alluxio.grpc.UpdateMountPRequest
-
the path of alluxio mount point
- getAlluxioPathBytes() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
-
the path of alluxio mount point
- getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string alluxio_path = 1;
- getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional string alluxio_path = 1;
- getAlluxioPathBytes() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional string alluxio_path = 1;
- getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
optional string alluxio_path = 1;
- getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
-
optional string alluxio_path = 1;
- getAlluxioPathBytes() - Method in interface alluxio.proto.journal.File.DeleteMountPointEntryOrBuilder
-
optional string alluxio_path = 1;
- getAlluxioStorageType() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getAlluxioStorageType() - Method in enum alluxio.client.ReadType
-
- getAlluxioStorageType() - Method in enum alluxio.client.WriteType
-
- getAlluxioUri() - Method in class alluxio.master.file.meta.options.MountInfo
-
- getAlluxioURIs(FileSystem, AlluxioURI) - Static method in class alluxio.cli.fs.FileSystemShellUtils
-
- getAlluxioVersion() - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- getAlluxioVersion() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional string alluxioVersion = 3;
- getAlluxioVersion() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
optional string alluxioVersion = 3;
- getAlluxioVersion() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
-
optional string alluxioVersion = 3;
- getAlluxioVersionBytes() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional string alluxioVersion = 3;
- getAlluxioVersionBytes() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
optional string alluxioVersion = 3;
- getAlluxioVersionBytes() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
-
optional string alluxioVersion = 3;
- getAllWorkerHealth() - Method in interface alluxio.client.job.JobMasterClient
-
Gets all worker health.
- getAllWorkerHealth() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- getAllWorkerHealth(GetAllWorkerHealthPRequest, StreamObserver<GetAllWorkerHealthPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
-
Lists all worker health.
- getAllWorkerHealth(GetAllWorkerHealthPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
-
Lists all worker health.
- getAllWorkerHealth(GetAllWorkerHealthPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
-
Lists all worker health.
- getAllWorkerHealth(GetAllWorkerHealthPRequest, StreamObserver<GetAllWorkerHealthPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
-
Lists all worker health.
- getAllWorkerHealth() - Method in class alluxio.master.job.JobMaster
-
- getAllWorkerHealth(GetAllWorkerHealthPRequest, StreamObserver<GetAllWorkerHealthPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
-
- GetAllWorkerHealthPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPOptions
- GetAllWorkerHealthPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPOptions
- GetAllWorkerHealthPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetAllWorkerHealthPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPRequest
- GetAllWorkerHealthPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPRequest
- GetAllWorkerHealthPRequestOrBuilder - Interface in alluxio.grpc
-
- GetAllWorkerHealthPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPResponse
- GetAllWorkerHealthPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPResponse
- GetAllWorkerHealthPResponseOrBuilder - Interface in alluxio.grpc
-
- getAllWorkers() - Method in class alluxio.client.file.FileSystemContext
-
Gets the worker information list.
- getAlwaysEnableTLS() - Method in class alluxio.grpc.GrpcChannelBuilder
-
- getAncestorInode() - Method in class alluxio.master.file.meta.LockedInodePath
-
Returns the closest ancestor of the target inode (last inode in the full path).
- getAndClearTaskUpdates() - Method in class alluxio.worker.job.task.TaskExecutorManager
-
- getAndLoad(PageId, int, int, ReadTargetBuffer, CacheContext, Supplier<byte[]>) - Method in interface alluxio.client.file.cache.CacheManager
-
Reads a part of a page if the queried page is found in the cache, stores the result in buffer.
- getAndLoad(PageId, int, int, ReadTargetBuffer, CacheContext, Supplier<byte[]>) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- getAndLoad(PageId, int, int, ReadTargetBuffer, CacheContext, Supplier<byte[]>) - Method in class alluxio.client.file.cache.LocalCacheManager
-
- getAndLoad(PageId, int, int, ReadTargetBuffer, CacheContext, Supplier<byte[]>) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- getAnnotation(PropertyKey) - Method in class alluxio.conf.DeprecatedKeyChecker
-
Returns the annotation attached to the given property key.
- getAppConfigurationEntry(String) - Method in class alluxio.security.login.LoginModuleConfiguration
-
- getArgs() - Method in class alluxio.stress.job.StressBenchConfig
-
- getArrayHeaderSize() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
-
Returns the fixed overhead of an array of any type or length in this JVM.
- getAsync() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional bool async = 6;
- getAsync() - Method in class alluxio.grpc.CacheRequest
-
optional bool async = 6;
- getAsync() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional bool async = 6;
- getAsyncCacheMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getAsyncMode() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns true
if this pool uses local first-in-first-out scheduling mode for forked
tasks that are never joined.
- getAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptions() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptionsBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptionsOrBuilder() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequest() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequestBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequestOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequestOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequestOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncWriteThreads() - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- getAttachDatabaseMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getAttemptCount() - Method in class alluxio.retry.CountingRetry
-
- getAttemptCount() - Method in interface alluxio.retry.RetryPolicy
-
How many retries have been performed.
- getAttemptCount() - Method in class alluxio.retry.SleepingRetry
-
- getAttemptCount() - Method in class alluxio.retry.TimeBoundedRetry
-
- getAttemptCount() - Method in class alluxio.retry.TimeoutRetry
-
- getattr(String, FileStat) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- getattr(String, FileStat) - Method in class alluxio.fuse.StackFS
-
- getattr(String, FileStat) - Method in interface alluxio.jnifuse.FuseFileSystem
-
- getattrCallback(String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- getAuditLogEntriesSize() - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
-
Gets the size of audit log entries.
- getAuthenticatedUserInfo() - Method in class alluxio.security.authentication.plain.SaslServerHandlerPlain
-
- getAuthenticatedUserInfo() - Method in interface alluxio.security.authentication.SaslServerHandler
-
Used to get the authenticated user info after the completed session.
- getAuthenticateMethod() - Static method in class alluxio.grpc.SaslAuthenticationServiceGrpc
-
- getAuthenticationScheme() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
- getAuthenticationScheme() - Method in class alluxio.grpc.SaslMessage
-
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
- getAuthenticationScheme() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
- getAuthenticationServer() - Method in class alluxio.grpc.GrpcServer
-
- getAuthInfo() - Method in class alluxio.s3.signature.AwsSignatureProcessor
-
Convert SignatureInfo to AwsAuthInfo.
- getAuthMethod(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
-
Gets the connection authentication method from the
ThreadLocal
variable.
- getAuthMethod() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
-
- getAuthority() - Method in class alluxio.AlluxioURI
-
- getAuthority() - Method in class alluxio.uri.StandardURI
-
- getAuthority() - Method in interface alluxio.uri.URI
-
- getAuthorizationID() - Method in class alluxio.security.authentication.plain.PlainSaslServer
-
- getAuthorizedUserName() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
-
- getAuthPolicy() - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
Get the file system authority policy.
- getAuthType() - Method in class alluxio.grpc.GrpcChannelBuilder
-
- getAvailable() - Method in class alluxio.extensions.ExtensionFactoryRegistry
-
Returns a read-only view of the available base factories.
- getAvailableBytes() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- getAvailableBytes() - Method in class alluxio.wire.JournalDiskInfo
-
- getAvailableBytes() - Method in interface alluxio.worker.block.meta.StorageDir
-
Gets the total available capacity of this
StorageDir
in bytes.
- getAvailableBytes() - Method in interface alluxio.worker.block.meta.StorageTier
-
- getAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional double avg_col_len = 2;
- getAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
optional double avg_col_len = 2;
- getAvgColLen() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
-
optional double avg_col_len = 2;
- getAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional double avg_col_len = 2;
- getAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional double avg_col_len = 2;
- getAvgColLen() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional double avg_col_len = 2;
- getAwsAccessId() - Method in class alluxio.s3.signature.SignatureInfo
-
- getAwsRegion() - Method in class alluxio.s3.signature.AwsCredential
-
- getAwsRequest() - Method in class alluxio.s3.signature.AwsCredential
-
- getAwsService() - Method in class alluxio.s3.signature.AwsCredential
-
- getBackupError() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional bytes backupError = 6;
- getBackupError() - Method in class alluxio.grpc.BackupPStatus
-
optional bytes backupError = 6;
- getBackupError() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional bytes backupError = 6;
- getBackupHost() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupHost = 3;
- getBackupHost() - Method in class alluxio.grpc.BackupPStatus
-
optional string backupHost = 3;
- getBackupHost() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional string backupHost = 3;
- getBackupHostBytes() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupHost = 3;
- getBackupHostBytes() - Method in class alluxio.grpc.BackupPStatus
-
optional string backupHost = 3;
- getBackupHostBytes() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional string backupHost = 3;
- getBackupId() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupId = 1;
- getBackupId() - Method in class alluxio.grpc.BackupPStatus
-
optional string backupId = 1;
- getBackupId() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional string backupId = 1;
- getBackupId() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
optional string backupId = 1;
- getBackupId() - Method in class alluxio.grpc.BackupStatusPRequest
-
optional string backupId = 1;
- getBackupId() - Method in interface alluxio.grpc.BackupStatusPRequestOrBuilder
-
optional string backupId = 1;
- getBackupId() - Method in class alluxio.master.backup.BackupRequestMessage
-
- getBackupId() - Method in class alluxio.wire.BackupStatus
-
- getBackupIdBytes() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupId = 1;
- getBackupIdBytes() - Method in class alluxio.grpc.BackupPStatus
-
optional string backupId = 1;
- getBackupIdBytes() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional string backupId = 1;
- getBackupIdBytes() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
optional string backupId = 1;
- getBackupIdBytes() - Method in class alluxio.grpc.BackupStatusPRequest
-
optional string backupId = 1;
- getBackupIdBytes() - Method in interface alluxio.grpc.BackupStatusPRequestOrBuilder
-
optional string backupId = 1;
- getBackupManager() - Method in class alluxio.master.CoreMasterContext
-
- getBackupMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
-
- getBackupRequest() - Method in class alluxio.master.backup.BackupRequestMessage
-
- getBackupState() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional .alluxio.grpc.meta.BackupState backupState = 2;
- getBackupState() - Method in class alluxio.grpc.BackupPStatus
-
optional .alluxio.grpc.meta.BackupState backupState = 2;
- getBackupState() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional .alluxio.grpc.meta.BackupState backupState = 2;
- getBackupStatus(UUID) - Method in interface alluxio.client.meta.MetaMasterClient
-
Queries the status of a backup.
- getBackupStatus(UUID) - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
-
- getBackupStatus(BackupStatusPRequest, StreamObserver<BackupPStatus>) - Method in interface alluxio.grpc.MetaMasterClientServiceGrpc.AsyncService
-
Returns status of the latest backup.
- getBackupStatus(BackupStatusPRequest) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
-
Returns status of the latest backup.
- getBackupStatus(BackupStatusPRequest) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
-
Returns status of the latest backup.
- getBackupStatus(BackupStatusPRequest, StreamObserver<BackupPStatus>) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
-
Returns status of the latest backup.
- getBackupStatus() - Method in class alluxio.master.backup.BackupHeartbeatMessage
-
- getBackupStatus(BackupStatusPRequest) - Method in class alluxio.master.backup.BackupLeaderRole
-
- getBackupStatus(BackupStatusPRequest) - Method in interface alluxio.master.backup.BackupOps
-
Used to query the status of a backup.
- getBackupStatus(BackupStatusPRequest) - Method in class alluxio.master.backup.BackupWorkerRole
-
- getBackupStatus(BackupStatusPRequest) - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getBackupStatus(BackupStatusPRequest, StreamObserver<BackupPStatus>) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
-
- getBackupUri() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupUri = 4;
- getBackupUri() - Method in class alluxio.grpc.BackupPStatus
-
optional string backupUri = 4;
- getBackupUri() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional string backupUri = 4;
- getBackupUri() - Method in class alluxio.wire.BackupStatus
-
- getBackupUriBytes() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupUri = 4;
- getBackupUriBytes() - Method in class alluxio.grpc.BackupPStatus
-
optional string backupUri = 4;
- getBackupUriBytes() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional string backupUri = 4;
- getBackupWorkerHostname() - Method in class alluxio.master.backup.BackupHandshakeMessage
-
- getBandwidth() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional int64 bandwidth = 1;
- getBandwidth() - Method in class alluxio.grpc.CopyJobPOptions
-
optional int64 bandwidth = 1;
- getBandwidth() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional int64 bandwidth = 1;
- getBandwidth() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional int64 bandwidth = 1;
- getBandwidth() - Method in class alluxio.grpc.LoadJobPOptions
-
optional int64 bandwidth = 1;
- getBandwidth() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
-
optional int64 bandwidth = 1;
- getBandwidth() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional int64 bandwidth = 1;
- getBandwidth() - Method in class alluxio.grpc.MoveJobPOptions
-
optional int64 bandwidth = 1;
- getBandwidth() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional int64 bandwidth = 1;
- getBandwidth() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
optional int64 bandwidth = 3;
- getBandwidth() - Method in class alluxio.grpc.UfsReadOptions
-
optional int64 bandwidth = 3;
- getBandwidth() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
-
optional int64 bandwidth = 3;
- getBandwidth() - Method in class alluxio.master.job.CopyJob
-
Get bandwidth.
- getBandwidth() - Method in class alluxio.master.job.DoraLoadJob
-
Get bandwidth.
- getBandwidth() - Method in class alluxio.master.job.LoadJob
-
Get bandwidth.
- getBandwidth() - Method in class alluxio.master.job.MoveJob
-
Get bandwidth.
- getBandwidth() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional int64 bandwidth = 4;
- getBandwidth() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional int64 bandwidth = 4;
- getBandwidth() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional int64 bandwidth = 4;
- getBandwidth() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional int64 bandwidth = 3;
- getBandwidth() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional int64 bandwidth = 3;
- getBandwidth() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional int64 bandwidth = 3;
- getBandwidth() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional int64 bandwidth = 4;
- getBandwidth() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional int64 bandwidth = 4;
- getBandwidth() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional int64 bandwidth = 4;
- getBaseLayout() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- getBaseLayout() - Method in class alluxio.grpc.table.Partition
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- getBaseLayout() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- getBaseLayoutBuilder() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- getBaseLayoutOrBuilder() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- getBaseLayoutOrBuilder() - Method in class alluxio.grpc.table.Partition
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- getBaseLayoutOrBuilder() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- getBaseName(String) - Static method in class alluxio.metrics.Metric
-
Gets the simple name without the tags.
- getBaseParameters() - Method in class alluxio.stress.client.ClientIOSummary
-
- getBaseParameters() - Method in class alluxio.stress.client.ClientIOTaskResult
-
- getBaseParameters() - Method in interface alluxio.stress.TaskResult
-
- getBaseParameters() - Method in class alluxio.stress.worker.IOTaskResult
-
- getBaseParameters() - Method in class alluxio.stress.worker.IOTaskSummary
-
- getBaseParameters() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- getBatchCount() - Method in class alluxio.worker.block.BlockMapIterator
-
Gets the number of batches.
- getBatchSize() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Batch size for partial listings.
- getBatchSize() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Batch size for partial listings.
- getBatchSize() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Batch size for partial listings.
- getBatchSize() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
-
- getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
-
- getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
-
Gets the batch size.
- getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.RenameBuffer
-
- getBenchDescription() - Method in class alluxio.stress.cli.Benchmark
-
Get the description of the bench.
- getBenchDescription() - Method in class alluxio.stress.cli.client.StressClientIOBench
-
- getBenchDescription() - Method in class alluxio.stress.cli.UfsIOBench
-
- getBenchDescription() - Method in class alluxio.stress.cli.worker.StressWorkerBench
-
- getBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBindAddress(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Helper method to get the bind hostname for a given service.
- getBindAddress() - Method in interface alluxio.worker.DataServer
-
Gets the actual bind socket address.
- getBindAddress() - Method in class alluxio.worker.grpc.GrpcDataServer
-
- getBindAddress() - Method in class alluxio.worker.netty.NettyDataServer
-
- getBindHost(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
-
- getBindHost() - Method in class alluxio.web.WebServer
-
Gets the actual bind hostname.
- getBindHostKey() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
-
Gets the key of bind hostname.
- getBindHostKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
-
Gets the key of bind hostname.
- getBindPort() - Method in class alluxio.grpc.GrpcServer
-
- getBits() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.Bits bits = 1;
- getBits() - Method in class alluxio.grpc.CheckAccessPOptions
-
optional .alluxio.grpc.Bits bits = 1;
- getBits() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
-
optional .alluxio.grpc.Bits bits = 1;
- getBitsPerClock() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
- getBitsPerScope() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
- getBitsPerSize() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
- getBitsPerTag() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
- getBitsPerTag() - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
-
- getBitsPerTag() - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
-
- getBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional string bit_vectors = 4;
- getBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
optional string bit_vectors = 4;
- getBitVectors() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
-
optional string bit_vectors = 4;
- getBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional string bit_vectors = 4;
- getBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
optional string bit_vectors = 4;
- getBitVectors() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
-
optional string bit_vectors = 4;
- getBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional string bit_vectors = 5;
- getBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional string bit_vectors = 5;
- getBitVectors() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- getBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional string bit_vectors = 5;
- getBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional string bit_vectors = 5;
- getBitVectors() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- getBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional string bit_vectors = 5;
- getBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional string bit_vectors = 5;
- getBitVectors() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- getBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional string bit_vectors = 5;
- getBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional string bit_vectors = 5;
- getBitVectors() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- getBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional string bit_vectors = 5;
- getBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional string bit_vectors = 5;
- getBitVectors() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional string bit_vectors = 4;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
optional string bit_vectors = 4;
- getBitVectorsBytes() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
-
optional string bit_vectors = 4;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional string bit_vectors = 4;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
optional string bit_vectors = 4;
- getBitVectorsBytes() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
-
optional string bit_vectors = 4;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional string bit_vectors = 5;
- getBitVectorsBytes() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- getBlock() - Method in class alluxio.grpc.BlockStatus.Builder
-
required .alluxio.grpc.block.Block block = 1;
- getBlock() - Method in class alluxio.grpc.BlockStatus
-
required .alluxio.grpc.block.Block block = 1;
- getBlock() - Method in interface alluxio.grpc.BlockStatusOrBuilder
-
required .alluxio.grpc.block.Block block = 1;
- getBlock(long) - Method in interface alluxio.master.metastore.BlockMetaStore
-
- getBlock(long) - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
-
- getBlock(long) - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
-
- getBlockBuilder() - Method in class alluxio.grpc.BlockStatus.Builder
-
required .alluxio.grpc.block.Block block = 1;
- getBlockChangeCount() - Method in class alluxio.worker.block.BlockHeartbeatReport
-
- getBlockClient() - Method in class alluxio.cli.fsadmin.command.Context
-
- getBlockContainerId() - Method in class alluxio.master.file.meta.InodeFile
-
- getBlockContainerId() - Method in interface alluxio.master.file.meta.InodeFileView
-
- getBlockContainerId() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- getBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- getBlockContainerIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- getBlockContainerIdGeneratorBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- getBlockContainerIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- getBlockContainerIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- getBlockContainerIdGeneratorOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- getBlockCount() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
- getBlockCount() - Method in class alluxio.grpc.GetRegisterLeasePRequest
-
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
- getBlockCount() - Method in interface alluxio.grpc.GetRegisterLeasePRequestOrBuilder
-
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
- getBlockCount() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
Return the block count of this worker.
- getBlockCount() - Method in class alluxio.util.webui.NodeInfo
-
Gets worker block count.
- getBlockCount() - Method in class alluxio.wire.WorkerInfo
-
- getBlockCount() - Method in class alluxio.wire.WorkerWebUIOverview
-
Gets block count.
- getBlockDeletionContext() - Method in class alluxio.master.file.RpcContext
-
- getBlockHeartbeatMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
-
- getBlockId() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.AsyncCacheRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.Block.Builder
-
required int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.Block
-
required int64 block_id = 1;
- getBlockId(int) - Method in class alluxio.grpc.BlockIdList.Builder
-
repeated int64 blockId = 1;
- getBlockId(int) - Method in class alluxio.grpc.BlockIdList
-
repeated int64 blockId = 1;
- getBlockId(int) - Method in interface alluxio.grpc.BlockIdListOrBuilder
-
repeated int64 blockId = 1;
- getBlockId() - Method in class alluxio.grpc.BlockInfo.Builder
-
optional int64 blockId = 1;
- getBlockId() - Method in class alluxio.grpc.BlockInfo
-
optional int64 blockId = 1;
- getBlockId() - Method in interface alluxio.grpc.BlockInfoOrBuilder
-
optional int64 blockId = 1;
- getBlockId() - Method in interface alluxio.grpc.BlockOrBuilder
-
required int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.CacheRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the id of the block being committed
- getBlockId() - Method in class alluxio.grpc.CommitBlockPRequest
-
the id of the block being committed
- getBlockId() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the id of the block being committed
- getBlockId() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
the id of the block
- getBlockId() - Method in class alluxio.grpc.GetBlockInfoPRequest
-
the id of the block
- getBlockId() - Method in interface alluxio.grpc.GetBlockInfoPRequestOrBuilder
-
the id of the block
- getBlockId() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.MoveBlockRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.grpc.MoveBlockRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.ReadRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.RemoveBlockRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.grpc.RemoveBlockRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.job.plan.replicate.MoveConfig
-
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCloseRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.proto.journal.Block.DeleteBlockEntryOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.wire.BlockInfo
-
- getBlockId() - Method in interface alluxio.worker.block.meta.BlockMeta
-
- getBlockId() - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- getBlockIdByIndex(int) - Method in class alluxio.master.file.meta.InodeFile
-
- getBlockIdByIndex(int) - Method in interface alluxio.master.file.meta.InodeFileView
-
Gets the block id for a given index.
- getBlockIdByIndex(int) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getBlockIdCount() - Method in class alluxio.grpc.BlockIdList.Builder
-
repeated int64 blockId = 1;
- getBlockIdCount() - Method in class alluxio.grpc.BlockIdList
-
repeated int64 blockId = 1;
- getBlockIdCount() - Method in interface alluxio.grpc.BlockIdListOrBuilder
-
repeated int64 blockId = 1;
- getBlockIdList() - Method in class alluxio.grpc.BlockIdList.Builder
-
repeated int64 blockId = 1;
- getBlockIdList() - Method in class alluxio.grpc.BlockIdList
-
repeated int64 blockId = 1;
- getBlockIdList() - Method in interface alluxio.grpc.BlockIdListOrBuilder
-
repeated int64 blockId = 1;
- getBlockIds() - Method in class alluxio.client.file.URIStatus
-
- getBlockIds(int) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated int64 blockIds = 13;
- getBlockIds(int) - Method in class alluxio.grpc.FileInfo
-
repeated int64 blockIds = 13;
- getBlockIds(int) - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated int64 blockIds = 13;
- getBlockIds(int) - Method in class alluxio.grpc.PersistFile.Builder
-
repeated int64 blockIds = 2;
- getBlockIds(int) - Method in class alluxio.grpc.PersistFile
-
repeated int64 blockIds = 2;
- getBlockIds(int) - Method in interface alluxio.grpc.PersistFileOrBuilder
-
repeated int64 blockIds = 2;
- getBlockIds() - Method in class alluxio.master.file.meta.InodeFile
-
- getBlockIds() - Method in interface alluxio.master.file.meta.InodeFileView
-
- getBlockIds() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getBlockIds(int) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
repeated int64 block_ids = 1;
- getBlockIds(int) - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
repeated int64 block_ids = 1;
- getBlockIds(int) - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
repeated int64 block_ids = 1;
- getBlockIds() - Method in class alluxio.util.webui.UIFileInfo
-
Gets BlockId List.
- getBlockIds() - Method in class alluxio.wire.FileInfo
-
- getBlockIds() - Method in class alluxio.wire.PersistFile
-
- getBlockIds() - Method in interface alluxio.worker.block.meta.StorageDir
-
Returns the list of block ids in this dir.
- getBlockIdsCount() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated int64 blockIds = 13;
- getBlockIdsCount() - Method in class alluxio.grpc.FileInfo
-
repeated int64 blockIds = 13;
- getBlockIdsCount() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated int64 blockIds = 13;
- getBlockIdsCount() - Method in class alluxio.grpc.PersistFile.Builder
-
repeated int64 blockIds = 2;
- getBlockIdsCount() - Method in class alluxio.grpc.PersistFile
-
repeated int64 blockIds = 2;
- getBlockIdsCount() - Method in interface alluxio.grpc.PersistFileOrBuilder
-
repeated int64 blockIds = 2;
- getBlockIdsCount() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
repeated int64 block_ids = 1;
- getBlockIdsCount() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
repeated int64 block_ids = 1;
- getBlockIdsCount() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
repeated int64 block_ids = 1;
- getBlockIdsList() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated int64 blockIds = 13;
- getBlockIdsList() - Method in class alluxio.grpc.FileInfo
-
repeated int64 blockIds = 13;
- getBlockIdsList() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated int64 blockIds = 13;
- getBlockIdsList() - Method in class alluxio.grpc.PersistFile.Builder
-
repeated int64 blockIds = 2;
- getBlockIdsList() - Method in class alluxio.grpc.PersistFile
-
repeated int64 blockIds = 2;
- getBlockIdsList() - Method in interface alluxio.grpc.PersistFileOrBuilder
-
repeated int64 blockIds = 2;
- getBlockIdsList() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
repeated int64 block_ids = 1;
- getBlockIdsList() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
repeated int64 block_ids = 1;
- getBlockIdsList() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
repeated int64 block_ids = 1;
- getBlockInfo(long) - Method in interface alluxio.client.block.BlockMasterClient
-
- getBlockInfo(long) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getBlockInfo(long) - Method in class alluxio.client.file.options.InStreamOptions
-
- getBlockInfo(long) - Method in class alluxio.client.file.URIStatus
-
- getBlockInfo(GetBlockInfoPRequest, StreamObserver<GetBlockInfoPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
-
Returns the block information for the given block id.
- getBlockInfo(GetBlockInfoPRequest) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
-
Returns the block information for the given block id.
- getBlockInfo(GetBlockInfoPRequest) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
-
Returns the block information for the given block id.
- getBlockInfo(GetBlockInfoPRequest, StreamObserver<GetBlockInfoPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
-
Returns the block information for the given block id.
- getBlockInfo() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfo() - Method in class alluxio.grpc.FileBlockInfo
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfo() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfo() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfo() - Method in class alluxio.grpc.GetBlockInfoPResponse
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfo() - Method in interface alluxio.grpc.GetBlockInfoPResponseOrBuilder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfo(long) - Method in interface alluxio.master.block.BlockMaster
-
- getBlockInfo(GetBlockInfoPRequest, StreamObserver<GetBlockInfoPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
-
- getBlockInfo(long) - Method in class alluxio.master.block.DefaultBlockMaster
-
- getBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- getBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- getBlockInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- getBlockInfo() - Method in class alluxio.wire.BlockLocationInfo
-
- getBlockInfo() - Method in class alluxio.wire.FileBlockInfo
-
- getBlockInfoBuilder() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfoBuilder() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfoBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- getBlockInfoList(List<Long>) - Method in interface alluxio.master.block.BlockMaster
-
Retrieves information for the given list of block ids.
- getBlockInfoList(List<Long>) - Method in class alluxio.master.block.DefaultBlockMaster
-
- getBlockInfoOrBuilder() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfoOrBuilder() - Method in class alluxio.grpc.FileBlockInfo
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfoOrBuilder() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfoOrBuilder() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfoOrBuilder() - Method in class alluxio.grpc.GetBlockInfoPResponse
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfoOrBuilder() - Method in interface alluxio.grpc.GetBlockInfoPResponseOrBuilder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- getBlockInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- getBlockInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- getBlockInfoOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- GetBlockInfoPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetBlockInfoPOptions
- GetBlockInfoPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetBlockInfoPOptions
- GetBlockInfoPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetBlockInfoPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetBlockInfoPRequest
- GetBlockInfoPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetBlockInfoPRequest
- GetBlockInfoPRequestOrBuilder - Interface in alluxio.grpc
-
- GetBlockInfoPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetBlockInfoPResponse
- GetBlockInfoPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetBlockInfoPResponse
- GetBlockInfoPResponseOrBuilder - Interface in alluxio.grpc
-
- getBlockLength() - Method in class alluxio.util.webui.UIFileBlockInfo
-
Gets block length.
- getBlockList() - Method in interface alluxio.worker.block.BlockStoreMeta
-
Note: This method is only available when users initialize
the blockStoreMeta with full block meta requirement.
- getBlockListByStorageLocation() - Method in interface alluxio.worker.block.BlockStoreMeta
-
Note: This method is only available when users initialize
the blockStoreMeta with full block meta requirement.
- getBlockLocation() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- getBlockLocation() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- getBlockLocation() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- getBlockLocation() - Method in interface alluxio.worker.block.meta.BlockMeta
-
- getBlockLocation() - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- getBlockLocationBuilder() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- getBlockLocationOrBuilder() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- getBlockLocationOrBuilder() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- getBlockLocationOrBuilder() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.DelegatingFileSystem
-
- getBlockLocations(URIStatus) - Method in class alluxio.client.file.DelegatingFileSystem
-
- getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.DoraCacheFileSystem
-
Get the location information of the specified file.
- getBlockLocations(URIStatus) - Method in class alluxio.client.file.DoraCacheFileSystem
-
Get the location information of the specified file.
- getBlockLocations(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
-
- getBlockLocations(URIStatus) - Method in interface alluxio.client.file.FileSystem
-
- getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- getBlockLocations(URIStatus) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.MetadataCachingFileSystem
-
- getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- getBlockLocations(URIStatus) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- getBlockMasterClient() - Method in class alluxio.multi.process.Clients
-
- getBlockMasterInfo(Set<BlockMasterInfo.BlockMasterInfoField>) - Method in interface alluxio.client.block.BlockMasterClient
-
- getBlockMasterInfo(Set<BlockMasterInfo.BlockMasterInfoField>) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getBlockMasterInfo(GetBlockMasterInfoPOptions, StreamObserver<GetBlockMasterInfoPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
-
Returns block master information.
- getBlockMasterInfo(GetBlockMasterInfoPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
-
Returns block master information.
- getBlockMasterInfo(GetBlockMasterInfoPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
-
Returns block master information.
- getBlockMasterInfo(GetBlockMasterInfoPOptions, StreamObserver<GetBlockMasterInfoPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
-
Returns block master information.
- getBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- getBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- getBlockMasterInfo() - Method in interface alluxio.grpc.GetBlockMasterInfoPResponseOrBuilder
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- getBlockMasterInfo(GetBlockMasterInfoPOptions, StreamObserver<GetBlockMasterInfoPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
-
- getBlockMasterInfoBuilder() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- getBlockMasterInfoOrBuilder() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- getBlockMasterInfoOrBuilder() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- getBlockMasterInfoOrBuilder() - Method in interface alluxio.grpc.GetBlockMasterInfoPResponseOrBuilder
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- GetBlockMasterInfoPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetBlockMasterInfoPOptions
- GetBlockMasterInfoPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetBlockMasterInfoPOptions
- GetBlockMasterInfoPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetBlockMasterInfoPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetBlockMasterInfoPResponse
- GetBlockMasterInfoPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetBlockMasterInfoPResponse
- GetBlockMasterInfoPResponseOrBuilder - Interface in alluxio.grpc
-
- getBlockMeta(long, long, long) - Method in interface alluxio.worker.block.BlockStore
-
Gets the metadata of a specific block from local storage.
- getBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
-
Gets the
BlockMeta
from this storage dir by its block id.
- getBlockMetaStore() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getBlockOrBuilder() - Method in class alluxio.grpc.BlockStatus.Builder
-
required .alluxio.grpc.block.Block block = 1;
- getBlockOrBuilder() - Method in class alluxio.grpc.BlockStatus
-
required .alluxio.grpc.block.Block block = 1;
- getBlockOrBuilder() - Method in interface alluxio.grpc.BlockStatusOrBuilder
-
required .alluxio.grpc.block.Block block = 1;
- getBlockReader() - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- getBlockReader() - Method in class alluxio.worker.netty.BlockReadRequestContext
-
- getBlockReplicaCount() - Method in interface alluxio.master.block.BlockMaster
-
- getBlockReplicaCount() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getBlocks(int) - Method in class alluxio.grpc.LoadRequest.Builder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocks(int) - Method in class alluxio.grpc.LoadRequest
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocks(int) - Method in interface alluxio.grpc.LoadRequestOrBuilder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocks() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- getBlocks() - Method in class alluxio.master.job.LoadJob.LoadTask
-
- getBlocks(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated int64 blocks = 12;
- getBlocks(int) - Method in class alluxio.proto.journal.File.InodeFileEntry
-
repeated int64 blocks = 12;
- getBlocks(int) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
repeated int64 blocks = 12;
- getBlocks(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated int64 blocks = 16;
- getBlocks(int) - Method in class alluxio.proto.meta.InodeMeta.Inode
-
repeated int64 blocks = 16;
- getBlocks(int) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
repeated int64 blocks = 16;
- getBlocks() - Method in interface alluxio.worker.block.meta.StorageDir
-
Returns the list of blocks stored in this dir.
- getBlocksBuilder(int) - Method in class alluxio.grpc.LoadRequest.Builder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksBuilderList() - Method in class alluxio.grpc.LoadRequest.Builder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksCount() - Method in class alluxio.grpc.LoadRequest.Builder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksCount() - Method in class alluxio.grpc.LoadRequest
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksCount() - Method in interface alluxio.grpc.LoadRequestOrBuilder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksCount() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated int64 blocks = 12;
- getBlocksCount() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
repeated int64 blocks = 12;
- getBlocksCount() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
repeated int64 blocks = 12;
- getBlocksCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated int64 blocks = 16;
- getBlocksCount() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
repeated int64 blocks = 16;
- getBlocksCount() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
repeated int64 blocks = 16;
- getBlockSize() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional int64 block_size = 3;
- getBlockSize() - Method in class alluxio.grpc.UfsFileStatus
-
optional int64 block_size = 3;
- getBlockSize() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
-
optional int64 block_size = 3;
- getBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The block size.
- getBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
The block size.
- getBlockSize() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
The block size.
- getBlockSize() - Method in class alluxio.underfs.UfsFileStatus
-
- getBlockSize() - Method in interface alluxio.worker.block.meta.BlockMeta
-
- getBlockSize() - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- getBlockSizeByte(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Gets the block size in bytes.
- getBlockSizeByte(String) - Method in interface alluxio.underfs.UnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
-
- getBlockSizeBytes() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getBlockSizeBytes() - Method in class alluxio.client.file.URIStatus
-
- getBlockSizeBytes() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int64 blockSizeBytes = 1;
- getBlockSizeBytes() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int64 blockSizeBytes = 1;
- getBlockSizeBytes() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int64 blockSizeBytes = 1;
- getBlockSizeBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 blockSizeBytes = 6;
- getBlockSizeBytes() - Method in class alluxio.grpc.FileInfo
-
optional int64 blockSizeBytes = 6;
- getBlockSizeBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 blockSizeBytes = 6;
- getBlockSizeBytes() - Method in class alluxio.master.file.meta.InodeFile
-
- getBlockSizeBytes() - Method in interface alluxio.master.file.meta.InodeFileView
-
- getBlockSizeBytes() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 block_size_bytes = 8;
- getBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 block_size_bytes = 8;
- getBlockSizeBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 block_size_bytes = 8;
- getBlockSizeBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 block_size_bytes = 2;
- getBlockSizeBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int64 block_size_bytes = 2;
- getBlockSizeBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int64 block_size_bytes = 2;
- getBlockSizeBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
file only
- getBlockSizeBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
file only
- getBlockSizeBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
file only
- getBlockSizeBytes() - Method in class alluxio.util.webui.UIFileInfo
-
Gets block size bytes.
- getBlockSizeBytes() - Method in class alluxio.wire.FileInfo
-
- getBlockSizeBytes() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets block size bytes.
- getBlockSizeBytes() - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Gets block size bytes.
- getBlocksList() - Method in class alluxio.grpc.LoadRequest.Builder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksList() - Method in class alluxio.grpc.LoadRequest
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksList() - Method in interface alluxio.grpc.LoadRequestOrBuilder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksList() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated int64 blocks = 12;
- getBlocksList() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
repeated int64 blocks = 12;
- getBlocksList() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
repeated int64 blocks = 12;
- getBlocksList() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated int64 blocks = 16;
- getBlocksList() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
repeated int64 blocks = 16;
- getBlocksList() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
repeated int64 blocks = 16;
- getBlocksOnTier() - Method in class alluxio.util.webui.UIFileInfo
-
Gets blocks on tier.
- getBlocksOrBuilder(int) - Method in class alluxio.grpc.LoadRequest.Builder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksOrBuilder(int) - Method in class alluxio.grpc.LoadRequest
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksOrBuilder(int) - Method in interface alluxio.grpc.LoadRequestOrBuilder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksOrBuilderList() - Method in class alluxio.grpc.LoadRequest.Builder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksOrBuilderList() - Method in class alluxio.grpc.LoadRequest
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlocksOrBuilderList() - Method in interface alluxio.grpc.LoadRequestOrBuilder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- getBlockStatus(int) - Method in class alluxio.grpc.LoadResponse.Builder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatus(int) - Method in class alluxio.grpc.LoadResponse
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatus(int) - Method in interface alluxio.grpc.LoadResponseOrBuilder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusBuilder(int) - Method in class alluxio.grpc.LoadResponse.Builder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusBuilderList() - Method in class alluxio.grpc.LoadResponse.Builder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusCount() - Method in class alluxio.grpc.LoadResponse.Builder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusCount() - Method in class alluxio.grpc.LoadResponse
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusCount() - Method in interface alluxio.grpc.LoadResponseOrBuilder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusList() - Method in class alluxio.grpc.LoadResponse.Builder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusList() - Method in class alluxio.grpc.LoadResponse
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusList() - Method in interface alluxio.grpc.LoadResponseOrBuilder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusOrBuilder(int) - Method in class alluxio.grpc.LoadResponse.Builder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusOrBuilder(int) - Method in class alluxio.grpc.LoadResponse
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusOrBuilder(int) - Method in interface alluxio.grpc.LoadResponseOrBuilder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusOrBuilderList() - Method in class alluxio.grpc.LoadResponse.Builder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusOrBuilderList() - Method in class alluxio.grpc.LoadResponse
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStatusOrBuilderList() - Method in interface alluxio.grpc.LoadResponseOrBuilder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- getBlockStore() - Method in interface alluxio.worker.block.BlockWorker
-
- getBlockStoreFactory() - Method in class alluxio.master.CoreMasterContext
-
- getBlockStoreFactory(String) - Static method in class alluxio.master.MasterUtils
-
- getBlockStoreMeta() - Method in interface alluxio.worker.block.BlockStore
-
Gets the metadata of the entire store in a snapshot.
- getBlockStoreMetaFull() - Method in interface alluxio.worker.block.BlockStore
-
- getBlockWorkerClientPoolMap() - Method in class alluxio.client.file.FileSystemContext
-
- getBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockStore
-
Creates a writer to write data to a temp block.
- getBlockWriter() - Method in class alluxio.worker.netty.BlockWriteRequestContext
-
- getBoolArg(CommandLine, Option, boolean) - Static method in class alluxio.cli.fs.FileSystemShellUtils
-
Gets the value of an option from the command line.
- getBoolean(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the boolean representation of the value for the given key.
- getBoolean(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the boolean representation of the value for the given key.
- getBoolean(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getBoolean(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanType() - Method in class alluxio.grpc.table.Value.Builder
-
bool boolean_type = 4;
- getBooleanType() - Method in class alluxio.grpc.table.Value
-
bool boolean_type = 4;
- getBooleanType() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
bool boolean_type = 4;
- getBucket() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- getBucket() - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
-
- getBucket() - Method in class alluxio.proxy.s3.ListMultipartUploadsResult
-
- getBucket() - Method in class alluxio.proxy.s3.ListPartsResult
-
- getBucket() - Method in class alluxio.proxy.s3.S3Handler
-
Get the bucket name of this request.
- getBucket(String, String, String, String, String, Integer, Integer, String, String, String, String, String, String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
-
Gets a bucket and lists all the objects or bucket tags in it.
- getBucket() - Method in class alluxio.worker.s3.S3NettyHandler
-
Get the bucket name of this request.
- getBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
optional int64 bucket_count = 2;
- getBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
optional int64 bucket_count = 2;
- getBucketCount() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
optional int64 bucket_count = 2;
- getBucketedBy(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated string bucketed_by = 1;
- getBucketedBy(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
repeated string bucketed_by = 1;
- getBucketedBy(int) - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
repeated string bucketed_by = 1;
- getBucketedByBytes(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated string bucketed_by = 1;
- getBucketedByBytes(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
repeated string bucketed_by = 1;
- getBucketedByBytes(int) - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
repeated string bucketed_by = 1;
- getBucketedByCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated string bucketed_by = 1;
- getBucketedByCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
repeated string bucketed_by = 1;
- getBucketedByCount() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
repeated string bucketed_by = 1;
- getBucketedByList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated string bucketed_by = 1;
- getBucketedByList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
repeated string bucketed_by = 1;
- getBucketedByList() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
repeated string bucketed_by = 1;
- getBucketIndex() - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
-
- getBucketName() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getBucketName(AlluxioURI) - Static method in class alluxio.util.UnderFileSystemUtils
-
- getBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- getBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- getBucketProperty() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- getBucketPropertyBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- getBucketPropertyOrBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- getBucketPropertyOrBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- getBucketPropertyOrBuilder() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- getBuckets() - Method in class alluxio.s3.ListAllMyBucketsResult
-
- getBuffer() - Method in class alluxio.grpc.DataMessage
-
- getBuffer() - Method in class alluxio.jnifuse.struct.FileStat
-
- getBufferFromStream(InputStream) - Static method in class alluxio.grpc.GrpcSerializationUtils
-
Gets a buffer directly from a gRPC input stream.
- getBuildVersion() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
the worker version to display in info pages (useful for rolling upgrades)
- getBuildVersion() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
the worker version to display in info pages (useful for rolling upgrades)
- getBuildVersion() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
-
the worker version to display in info pages (useful for rolling upgrades)
- getBuildVersion() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- getBuildVersion() - Method in class alluxio.grpc.WorkerInfo
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- getBuildVersion() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- getBuildVersion() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
Get the build version of the worker.
- getBuildVersionBuilder() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
the worker version to display in info pages (useful for rolling upgrades)
- getBuildVersionBuilder() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- getBuildVersionOrBuilder() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
the worker version to display in info pages (useful for rolling upgrades)
- getBuildVersionOrBuilder() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
the worker version to display in info pages (useful for rolling upgrades)
- getBuildVersionOrBuilder() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
-
the worker version to display in info pages (useful for rolling upgrades)
- getBuildVersionOrBuilder() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- getBuildVersionOrBuilder() - Method in class alluxio.grpc.WorkerInfo
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- getBuildVersionOrBuilder() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- getByField(V) - Method in interface alluxio.collections.FieldIndex
-
Gets a subset of objects with the specified field value.
- getByField(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
-
Gets a subset of objects with the specified field value.
- getByField(V) - Method in class alluxio.collections.NonUniqueFieldIndex
-
- getByField(V) - Method in class alluxio.collections.UniqueFieldIndex
-
- getBypassDelegation() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool bypassDelegation = 4;
- getBypassDelegation() - Method in class alluxio.grpc.BackupPOptions
-
optional bool bypassDelegation = 4;
- getBypassDelegation() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
-
optional bool bypassDelegation = 4;
- getByteBufFromReadableBuffer(ReadableBuffer) - Static method in class alluxio.grpc.GrpcSerializationUtils
-
Gets a Netty buffer directly from a gRPC ReadableBuffer.
- getBytes(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the bytes of the value for the given key.
- getBytes(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the bytes of the value for the given key.
- getBytes(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
optional int64 bytes = 1;
- getBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse
-
optional int64 bytes = 1;
- getBytes() - Method in interface alluxio.grpc.GetCapacityBytesPResponseOrBuilder
-
optional int64 bytes = 1;
- getBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
optional int64 bytes = 1;
- getBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse
-
optional int64 bytes = 1;
- getBytes() - Method in interface alluxio.grpc.GetUsedBytesPResponseOrBuilder
-
optional int64 bytes = 1;
- getBytes(long, byte[]) - Method in class alluxio.inode.RocksBenchBase
-
- getBytes(long) - Method in class alluxio.inode.RocksBenchBase
-
- getBytes(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getBytesRead() - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
-
Gets the number of bytes that has been received and written into the output channel.
- getBytesRead() - Method in exception alluxio.client.file.dora.netty.PartialReadException
-
- getBytesReserved() - Method in class alluxio.worker.netty.BlockWriteRequestContext
-
- getBytesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
optional int64 bytes_skipped = 4;
- getBytesSkipped() - Method in class alluxio.grpc.LoadFileResponse
-
optional int64 bytes_skipped = 4;
- getBytesSkipped() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
optional int64 bytes_skipped = 4;
- getBytesWanted() - Method in exception alluxio.client.file.dora.netty.PartialReadException
-
- getBytesWritten() - Method in class alluxio.client.file.FileOutStream
-
- getBytesWritten() - Method in class alluxio.client.file.ufs.UfsFileOutStream
-
- getCacheable() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool cacheable = 11;
- getCacheable() - Method in class alluxio.grpc.FileInfo
-
optional bool cacheable = 11;
- getCacheable() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool cacheable = 11;
- getCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool cacheable = 11;
- getCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional bool cacheable = 11;
- getCacheable() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional bool cacheable = 11;
- getCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional bool cacheable = 5;
- getCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional bool cacheable = 5;
- getCacheable() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional bool cacheable = 5;
- getCacheContext() - Method in class alluxio.client.file.URIStatus
-
- getCached(long, String, String) - Static method in class alluxio.util.proto.BlockLocationUtils
-
Get a shared grpc block location object.
- getCached(Block.BlockLocation) - Static method in class alluxio.util.proto.BlockLocationUtils
-
Get a shared grpc block location object.
- getCachedBlockLocationSize() - Static method in class alluxio.util.proto.BlockLocationUtils
-
Gets the cached block location size.
- getCachedBytes() - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
- getCachedGaugeTimeoutMillis() - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
-
- getCachedPageIdsByFileId(String, long) - Method in interface alluxio.client.file.cache.CacheManager
-
Get page ids by the given file id.
- getCachedPageIdsByFileId(String, long) - Method in class alluxio.client.file.cache.LocalCacheManager
-
- getCachedPageIdsByFileId(String, long) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- getCachedPercentage(FileInfo, String) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getCachedWorkers() - Method in class alluxio.client.file.FileSystemContext
-
Gets the cached live worker information list.
- getCachedWorkers(FileSystemContext.GetWorkerListType) - Method in class alluxio.client.file.FileSystemContext
-
Gets the cached worker information list.
- getCacheEnabled() - Method in class alluxio.client.file.cache.context.CachePerThreadContext
-
- getCacheEvictorOptions() - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- getCacheHit() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets cache hit.
- getCacheIdentifier() - Method in class alluxio.client.file.CacheContext
-
Returns an string as a hint from computation to indicate the file.
- getCacheMap() - Method in class alluxio.master.metastore.caching.Cache
-
- getCacheMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getCacheMiss() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets cache miss.
- getCacheQuota() - Method in class alluxio.client.file.CacheContext
-
- getCacheScope() - Method in class alluxio.client.file.CacheContext
-
- getCacheSize() - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- getCacheSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional int64 cacheSize = 2;
- getCacheSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
optional int64 cacheSize = 2;
- getCacheSize() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
-
optional int64 cacheSize = 2;
- getCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
optional bool cancel = 2;
- getCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
optional bool cancel = 2;
- getCancel() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
-
optional bool cancel = 2;
- getCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
If set, this request is to cancel the reading request for the id.
- getCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
If set, this request is to cancel the reading request for the id.
- getCancel() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
If set, this request is to cancel the reading request for the id.
- getCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional bool cancel = 6;
- getCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
optional bool cancel = 6;
- getCancel() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
optional bool cancel = 6;
- getCancelledTrackers() - Method in class alluxio.master.file.contexts.OperationContext
-
- getCancelMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getCancelState() - Method in class alluxio.master.file.PersistJob
-
- getCancelTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommand() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommandBuilder() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommandOrBuilder() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommandOrBuilder() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommandOrBuilder() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCandidates(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidates(int) - Method in class alluxio.grpc.table.EquatableValueSet
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidates(int) - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesBuilder(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesBuilderList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesCount() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesCount() - Method in class alluxio.grpc.table.EquatableValueSet
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesCount() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesList() - Method in class alluxio.grpc.table.EquatableValueSet
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesList() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilder(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilder(int) - Method in class alluxio.grpc.table.EquatableValueSet
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilder(int) - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilderList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilderList() - Method in class alluxio.grpc.table.EquatableValueSet
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilderList() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCanonical(Class<W>) - Method in class alluxio.Registry
-
- getCanonical(Class<W>, int) - Method in class alluxio.Registry
-
Gets the server registered with the canonical type.
- getCanonicalServiceName() - Method in class alluxio.hadoop.AbstractFileSystem
-
- getCanonicalVersion() - Method in enum alluxio.underfs.hdfs.HdfsVersion
-
- getCanRegisterAgain() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
optional bool canRegisterAgain = 3;
- getCanRegisterAgain() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
optional bool canRegisterAgain = 3;
- getCanRegisterAgain() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
-
optional bool canRegisterAgain = 3;
- getCapacity() - Method in class alluxio.util.webui.NodeInfo
-
Gets capacity.
- getCapacity() - Method in class alluxio.util.webui.StorageTierInfo
-
Gets capacity.
- getCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getCapacity() - Method in class alluxio.wire.AlluxioWorkerInfo
-
- getCapacity() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets capacity.
- getCapacityBytes() - Method in interface alluxio.client.block.BlockMasterClient
-
Gets the total Alluxio capacity in bytes, on all the tiers of all the workers.
- getCapacityBytes() - Method in class alluxio.client.block.BlockStoreClient
-
Gets the total capacity of Alluxio's BlockStore.
- getCapacityBytes() - Method in class alluxio.client.block.BlockWorkerInfo
-
- getCapacityBytes() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getCapacityBytes() - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
- getCapacityBytes(GetCapacityBytesPOptions, StreamObserver<GetCapacityBytesPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
-
Returns the capacity (in bytes).
- getCapacityBytes(GetCapacityBytesPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
-
Returns the capacity (in bytes).
- getCapacityBytes(GetCapacityBytesPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
-
Returns the capacity (in bytes).
- getCapacityBytes(GetCapacityBytesPOptions, StreamObserver<GetCapacityBytesPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
-
Returns the capacity (in bytes).
- getCapacityBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 capacityBytes = 1;
- getCapacityBytes() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int64 capacityBytes = 1;
- getCapacityBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int64 capacityBytes = 1;
- getCapacityBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 capacityBytes = 5;
- getCapacityBytes() - Method in class alluxio.grpc.WorkerInfo
-
optional int64 capacityBytes = 5;
- getCapacityBytes() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional int64 capacityBytes = 5;
- getCapacityBytes() - Method in interface alluxio.master.block.BlockMaster
-
- getCapacityBytes(GetCapacityBytesPOptions, StreamObserver<GetCapacityBytesPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
-
- getCapacityBytes() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getCapacityBytes() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- getCapacityBytes() - Method in class alluxio.util.webui.UIStorageDir
-
Gets capacity bytes.
- getCapacityBytes() - Method in class alluxio.util.webui.UIUsageOnTier
-
Gets capacity bytes.
- getCapacityBytes() - Method in class alluxio.wire.BlockMasterInfo
-
- getCapacityBytes() - Method in class alluxio.wire.WorkerInfo
-
- getCapacityBytes() - Method in class alluxio.wire.WorkerWebUIOverview
-
Gets capacity bytes.
- getCapacityBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
-
- getCapacityBytes() - Method in class alluxio.worker.block.BlockWorkerMetrics
-
- getCapacityBytes() - Method in interface alluxio.worker.block.meta.StorageDir
-
Gets the total capacity of this
StorageDir
in bytes, which is a constant once this
StorageDir
has been initialized.
- getCapacityBytes() - Method in interface alluxio.worker.block.meta.StorageTier
-
- getCapacityBytesOnDirs() - Method in interface alluxio.worker.block.BlockStoreMeta
-
- getCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
Deprecated.
- getCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
Deprecated.
- getCapacityBytesOnTiers() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
Deprecated.
- getCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
Deprecated.
- getCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo
-
Deprecated.
- getCapacityBytesOnTiers() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
Deprecated.
- getCapacityBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
-
Deprecated.
- getCapacityBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo
-
Deprecated.
- getCapacityBytesOnTiers() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
Deprecated.
- getCapacityBytesOnTiers() - Method in class alluxio.wire.BlockMasterInfo
-
- getCapacityBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
-
- getCapacityBytesOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
-
- getCapacityBytesOnTiers() - Method in class alluxio.worker.block.BlockWorkerMetrics
-
- getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
- getCapacityBytesOnTiersCount() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.BlockMasterInfo
-
- getCapacityBytesOnTiersCount() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.WorkerInfo.Builder
-
- getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.WorkerInfo
-
- getCapacityBytesOnTiersCount() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
map<string, int64> capacityBytesOnTiers = 8;
- getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersMap() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.BlockMasterInfo
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersMap() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.WorkerInfo.Builder
-
map<string, int64> capacityBytesOnTiers = 8;
- getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.WorkerInfo
-
map<string, int64> capacityBytesOnTiers = 8;
- getCapacityBytesOnTiersMap() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
map<string, int64> capacityBytesOnTiers = 8;
- getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockMasterInfo
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.WorkerInfo.Builder
-
map<string, int64> capacityBytesOnTiers = 8;
- getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.WorkerInfo
-
map<string, int64> capacityBytesOnTiers = 8;
- getCapacityBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
map<string, int64> capacityBytesOnTiers = 8;
- getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockMasterInfo
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
map<string, int64> capacityBytesOnTiers = 2;
- getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.WorkerInfo.Builder
-
map<string, int64> capacityBytesOnTiers = 8;
- getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.WorkerInfo
-
map<string, int64> capacityBytesOnTiers = 8;
- getCapacityBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
map<string, int64> capacityBytesOnTiers = 8;
- GetCapacityBytesPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetCapacityBytesPOptions
- GetCapacityBytesPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetCapacityBytesPOptions
- GetCapacityBytesPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetCapacityBytesPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetCapacityBytesPResponse
- GetCapacityBytesPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetCapacityBytesPResponse
- GetCapacityBytesPResponseOrBuilder - Interface in alluxio.grpc
-
- getCapacityFree() - Method in class alluxio.worker.block.BlockWorkerMetrics
-
- getCatchupState() - Method in class alluxio.master.journal.ufs.UfsJournal
-
- getCatchupState() - Method in class alluxio.master.journal.ufs.UfsJournalCheckpointThread
-
- getCauseType() - Method in exception alluxio.client.file.dora.netty.PartialReadException
-
- getChannel() - Method in class alluxio.grpc.GrpcChannel
-
- getChannel() - Method in class alluxio.network.netty.NettyRPCContext
-
- getChannel() - Method in class alluxio.worker.block.io.BlockReader
-
Returns a readable byte channel of the block.
- getChannel() - Method in class alluxio.worker.block.io.BlockWriter
-
- getChannel() - Method in class alluxio.worker.dora.PagedFileReader
-
- getChannel() - Method in class alluxio.worker.dora.PagedFileWriter
-
- getChannelClass(boolean, PropertyKey, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
-
Get the proper channel class.
- getChannelId() - Method in class alluxio.grpc.GrpcChannelKey
-
- getChannelKey() - Method in class alluxio.grpc.GrpcChannel
-
- getChannelRef() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string channelRef = 5;
- getChannelRef() - Method in class alluxio.grpc.SaslMessage
-
optional string channelRef = 5;
- getChannelRef() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional string channelRef = 5;
- getChannelRefBytes() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string channelRef = 5;
- getChannelRefBytes() - Method in class alluxio.grpc.SaslMessage
-
optional string channelRef = 5;
- getChannelRefBytes() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional string channelRef = 5;
- getChannelType(PropertyKey, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
-
Get the proper channel type.
- getCheckAccessMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getCheckConsistencyMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getCheckContent() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool check_content = 6;
- getCheckContent() - Method in class alluxio.grpc.CopyJobPOptions
-
optional bool check_content = 6;
- getCheckContent() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional bool check_content = 6;
- getCheckContent() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool check_content = 6;
- getCheckContent() - Method in class alluxio.grpc.MoveJobPOptions
-
optional bool check_content = 6;
- getCheckContent() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional bool check_content = 6;
- getCheckContent() - Method in class alluxio.grpc.WriteOptions.Builder
-
optional bool check_content = 3;
- getCheckContent() - Method in class alluxio.grpc.WriteOptions
-
optional bool check_content = 3;
- getCheckContent() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
-
optional bool check_content = 3;
- getCheckContent() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional bool check_content = 11;
- getCheckContent() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional bool check_content = 11;
- getCheckContent() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional bool check_content = 11;
- getCheckContent() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional bool check_content = 11;
- getCheckContent() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional bool check_content = 11;
- getCheckContent() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional bool check_content = 11;
- getCheckpoint() - Method in interface alluxio.master.journal.JournalReader
-
Returns the input stream for reading a checkpoint.
- getCheckpoint() - Method in class alluxio.master.journal.ufs.UfsJournalReader
-
- getCheckpoint() - Method in class alluxio.master.journalv0.ufs.UfsJournal
-
- getCheckpointFormat() - Method in enum alluxio.master.journal.checkpoint.CheckpointType
-
- getCheckpointInputStream() - Method in interface alluxio.master.journalv0.JournalReader
-
- getCheckpointInputStream() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
-
- getCheckpointLastModifiedTimeMs() - Method in interface alluxio.master.journalv0.JournalReader
-
- getCheckpointLastModifiedTimeMs() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
-
- getCheckpointMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
-
- getCheckpointName() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getCheckpointName() - Method in class alluxio.master.block.DefaultBlockMasterContainerIdJournaled
-
- getCheckpointName() - Method in class alluxio.master.file.meta.InodeCounter
-
- getCheckpointName() - Method in class alluxio.master.file.meta.InodeDirectoryIdGenerator
-
- getCheckpointName() - Method in class alluxio.master.file.meta.InodeTreePersistentState
-
- getCheckpointName() - Method in class alluxio.master.file.meta.MountTable.State
-
- getCheckpointName() - Method in class alluxio.master.file.meta.PinnedInodeFileIds
-
- getCheckpointName() - Method in class alluxio.master.file.meta.ReplicationLimitedFileIds
-
- getCheckpointName() - Method in class alluxio.master.file.meta.ToBePersistedFileIds
-
- getCheckpointName() - Method in class alluxio.master.file.meta.TtlBucketList
-
- getCheckpointName() - Method in interface alluxio.master.journal.checkpoint.Checkpointed
-
- getCheckpointName() - Method in interface alluxio.master.journal.DelegatingJournaled
-
- getCheckpointName() - Method in class alluxio.master.journal.JournaledGroup
-
- getCheckpointName() - Method in interface alluxio.master.journal.NoopJournaled
-
- getCheckpointName() - Method in class alluxio.master.journal.raft.SnapshotIdJournaled
-
- getCheckpointName() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getCheckpointName() - Method in class alluxio.master.meta.DefaultMetaMaster.State
-
- getCheckpointName() - Method in class alluxio.master.meta.PathProperties.State
-
- getCheckpointName() - Method in class alluxio.master.metastore.caching.CachingInodeStore
-
- getCheckpointName() - Method in class alluxio.master.metastore.heap.HeapInodeStore
-
- getCheckpointName() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
-
- getCheckpointName() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- getCheckpointName() - Method in class alluxio.master.scheduler.JournaledJobMetaStore
-
- getCheckpointOutputStream(long) - Method in interface alluxio.master.journalv0.JournalWriter
-
Returns an output stream for the journal checkpoint.
- getCheckpointOutputStream(long) - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
-
- getCheckpoints() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
-
- getCheckpointWriter(long) - Method in class alluxio.master.journal.ufs.UfsJournal
-
- getCheckS3BucketPath() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool checkS3BucketPath = 8;
- getCheckS3BucketPath() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional bool checkS3BucketPath = 8;
- getCheckS3BucketPath() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional bool checkS3BucketPath = 8;
- getCheckS3BucketPath() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool checkS3BucketPath = 14;
- getCheckS3BucketPath() - Method in class alluxio.grpc.CreateFilePOptions
-
optional bool checkS3BucketPath = 14;
- getCheckS3BucketPath() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional bool checkS3BucketPath = 14;
- getCheckUfs() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
optional bool checkUfs = 1;
- getCheckUfs() - Method in class alluxio.grpc.GetMountTablePRequest
-
optional bool checkUfs = 1;
- getCheckUfs() - Method in interface alluxio.grpc.GetMountTablePRequestOrBuilder
-
optional bool checkUfs = 1;
- getChild(Long, String, ReadOption) - Method in class alluxio.master.metastore.caching.CachingInodeStore
-
- getChild(Long, String, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- getChild(InodeDirectoryView, String, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- getChild(Long, String, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
-
- getChild(Long, String, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChild(Long, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChild(InodeDirectoryView, String, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChild(InodeDirectoryView, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChild(Long, String, ReadOption) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- getChildCount() - Method in class alluxio.master.file.meta.InodeDirectory
-
- getChildCount() - Method in interface alluxio.master.file.meta.InodeDirectoryView
-
- getChildCount() - Method in class alluxio.master.file.meta.MutableInodeDirectory
-
- getChildCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 child_count = 26;
- getChildCount() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 child_count = 26;
- getChildCount() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 child_count = 26;
- getChildId() - Method in class alluxio.master.file.meta.EdgeEntry
-
- getChildId(Long, String, ReadOption) - Method in class alluxio.master.metastore.caching.CachingInodeStore
-
- getChildId(Long, String, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- getChildId(InodeDirectoryView, String, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- getChildId(Long, String, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
-
- getChildId(Long, String, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChildId(Long, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChildId(InodeDirectoryView, String, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChildId(Long, String, ReadOption) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- getChildIds(Long, ReadOption) - Method in class alluxio.master.metastore.caching.CachingInodeStore
-
- getChildIds(Long, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- getChildIds(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- getChildIds(Long, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
-
- getChildIds(Long, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
Returns an iterable for the ids of the children of the given directory.
- getChildIds(Long) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChildIds(InodeDirectoryView, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
Returns an iterable for the ids of the children of the given directory.
- getChildIds(Long, ReadOption) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- getChildName() - Method in class alluxio.master.file.meta.EdgeEntry
-
- getChildName(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Gets the child name based on the parent name.
- getChildren(T) - Method in class alluxio.collections.DirectedAcyclicGraph
-
Gets the payloads for the children of the given node.
- getChildren() - Method in class alluxio.collections.DirectedAcyclicGraphNode
-
Gets the children nodes of the node.
- getChildren(int) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildren(int) - Method in class alluxio.grpc.JobInfo
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildren(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildren() - Method in interface alluxio.job.wire.JobInfo
-
- getChildren() - Method in class alluxio.job.wire.PlanInfo
-
- getChildren() - Method in class alluxio.job.wire.TaskInfo
-
- getChildren() - Method in class alluxio.job.wire.WorkflowInfo
-
- getChildren(Long, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- getChildren(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- getChildren(Long, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
-
- getChildren(Long, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
Returns an iterator over the children of the specified inode.
- getChildren(Long) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChildren(InodeDirectoryView, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChildren(InodeDirectoryView) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- getChildren(String) - Method in class alluxio.membership.AlluxioEtcdClient
-
Get list of children path kv pairs from a given parentPath
e.g.
- getChildren(AlluxioURI) - Method in class alluxio.underfs.UfsStatusCache
-
- getChildrenBuilder(int) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenBuilderList() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenCount() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenCount() - Method in class alluxio.grpc.JobInfo
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenCount() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenFrom(long, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
Returns a closeable stream of the inodes sorted by filename of the children of the given
directory that come after and including fromName.
- getChildrenList() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenList() - Method in class alluxio.grpc.JobInfo
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenList() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenOrBuilder(int) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenOrBuilder(int) - Method in class alluxio.grpc.JobInfo
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenOrBuilder(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenOrBuilderList() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenOrBuilderList() - Method in class alluxio.grpc.JobInfo
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenOrBuilderList() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- getChildrenPrefix(long, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
Returns a closeable stream of the inodes sorted by filename of the children of the given
directory that come after and including fromName.
- getChildrenPrefixFrom(long, String, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
Returns a closeable stream of the inodes sorted by filename of the children of the given
directory that come after and including fromName, and matching the prefix.
- getChunk() - Method in class alluxio.grpc.ReadResponse.Builder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunk() - Method in class alluxio.grpc.ReadResponse
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunk() - Method in interface alluxio.grpc.ReadResponseOrBuilder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunk() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional bytes chunk = 3;
- getChunk() - Method in class alluxio.grpc.SnapshotData
-
optional bytes chunk = 3;
- getChunk() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
optional bytes chunk = 3;
- getChunk() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunk() - Method in class alluxio.grpc.WriteRequest
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunk() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunkBuilder() - Method in class alluxio.grpc.ReadResponse.Builder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunkBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunkOrBuilder() - Method in class alluxio.grpc.ReadResponse.Builder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunkOrBuilder() - Method in class alluxio.grpc.ReadResponse
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunkOrBuilder() - Method in interface alluxio.grpc.ReadResponseOrBuilder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunkOrBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunkOrBuilder() - Method in class alluxio.grpc.WriteRequest
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunkOrBuilder() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunkSize() - Method in class alluxio.client.file.dora.DoraCacheClient
-
- getChunkSize() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 chunk_size = 5;
- getChunkSize() - Method in class alluxio.grpc.ReadRequest
-
optional int64 chunk_size = 5;
- getChunkSize() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
optional int64 chunk_size = 5;
- getChunkSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
If set, the server should send packets in the specified packet size.
- getChunkSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
If set, the server should send packets in the specified packet size.
- getChunkSize() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
If set, the server should send packets in the specified packet size.
- getChunkSize() - Method in class alluxio.wire.BlockReadRequest
-
- getClass(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the value for the given key as a class.
- getClass(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the value for the given key as a class.
- getClass(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getClass(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getClassName() - Method in enum alluxio.master.MasterHealthCheckClient.MasterType
-
- getClassName() - Method in class alluxio.stress.job.StressBenchConfig
-
- getClassName() - Method in interface alluxio.util.JsonSerializable
-
- getCleanedPathComponents(String) - Static method in class alluxio.util.io.PathUtils
-
Get the components of a path that has already been cleaned.
- getClearMetricsMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getClearMetricsMethod() - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
-
- getClient() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
- getClient(FileSystemContext) - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
- getClient() - Method in class alluxio.master.ClientPool
-
- getClient(FileSystemContext) - Method in class alluxio.master.ClientPool
-
Returns a
FileSystem
client using a specific context.
- getClient() - Method in class alluxio.master.LocalAlluxioCluster
-
- getClient(FileSystemContext) - Method in class alluxio.master.LocalAlluxioCluster
-
- getClient() - Method in class alluxio.master.LocalAlluxioMaster
-
- getClient(FileSystemContext) - Method in class alluxio.master.LocalAlluxioMaster
-
- getClient() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- getClient(FileSystemContext) - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- getClient() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- getClient(FileSystemContext) - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- getClient(String, String, String, int, boolean) - Static method in class alluxio.master.ZkMasterInquireClient
-
Gets the client.
- getClient() - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
-
- getClient() - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
-
- getClient() - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
-
- getClient() - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
-
- getClient() - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
-
- getClient() - Method in class alluxio.underfs.s3a.S3AInputStream
-
- getClient() - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
-
- getClient() - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
-
- getClient() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getClientChannelClass(boolean) - Static method in class alluxio.util.network.NettyUtils
-
Returns the correct
SocketChannel
class based on
ChannelType
.
- getClientContext() - Method in class alluxio.client.file.FileSystemContext
-
- getClientHostName(AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Gets the local hostname to be used by the client.
- getClientId() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string clientId = 3;
- getClientId() - Method in class alluxio.grpc.SaslMessage
-
optional string clientId = 3;
- getClientId() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional string clientId = 3;
- getClientIdBytes() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string clientId = 3;
- getClientIdBytes() - Method in class alluxio.grpc.SaslMessage
-
optional string clientId = 3;
- getClientIdBytes() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional string clientId = 3;
- getClientList() - Method in class alluxio.worker.block.BlockMasterClientPool
-
- getClientMetrics(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetrics(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetrics(int) - Method in interface alluxio.grpc.MetricsHeartbeatPOptionsOrBuilder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsBuilder(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsBuilderList() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsCount() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsCount() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsCount() - Method in interface alluxio.grpc.MetricsHeartbeatPOptionsOrBuilder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsList() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsList() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsList() - Method in interface alluxio.grpc.MetricsHeartbeatPOptionsOrBuilder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsOrBuilder(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsOrBuilder(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsOrBuilder(int) - Method in interface alluxio.grpc.MetricsHeartbeatPOptionsOrBuilder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsOrBuilderList() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsOrBuilderList() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClientMetricsOrBuilderList() - Method in interface alluxio.grpc.MetricsHeartbeatPOptionsOrBuilder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- getClients() - Method in class alluxio.multi.process.MultiProcessCluster
-
- getClientSslContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
-
- getClientSslContext() - Method in interface alluxio.util.network.tls.SslContextProvider
-
- getClientUser(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
-
- getClientVersion() - Static method in class alluxio.security.authentication.ClientContextServerInjector
-
- getClock() - Method in interface alluxio.master.block.BlockMaster
-
Returns the BlockMaster's clock so other components can align with
the BlockMaster's time.
- getClock() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getClock() - Method in class alluxio.time.TimeContext
-
- getCloseableIterator() - Method in interface alluxio.master.metastore.BlockMetaStore
-
- getCloseableIterator() - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
-
- getCloseableIterator() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
-
- getCloseableIterator() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
Acquires an iterator to iterate all Inodes in RocksDB.
- getCloser() - Method in class alluxio.cli.fsadmin.command.Context
-
- getCloser() - Method in class alluxio.grpc.GrpcService
-
Gets the closer associated with this service.
- getClusterConf() - Method in class alluxio.client.file.FileSystemContext
-
- getClusterConf() - Method in class alluxio.ClientContext
-
- getClusterConf(GetConfigurationPResponse, AlluxioConfiguration, Scope) - Static method in class alluxio.conf.Configuration
-
Loads the cluster level configuration from the get configuration response,
filters out the configuration for certain scope, and merges it with the existing configuration.
- getClusterConf() - Method in class alluxio.wire.Configuration
-
- getClusterConfHash() - Method in class alluxio.ClientContext
-
- getClusterConfHash() - Method in class alluxio.wire.Configuration
-
- getClusterConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string clusterConfigHash = 1;
- getClusterConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse
-
optional string clusterConfigHash = 1;
- getClusterConfigHash() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
-
optional string clusterConfigHash = 1;
- getClusterConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string clusterConfigHash = 3;
- getClusterConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse
-
optional string clusterConfigHash = 3;
- getClusterConfigHash() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
optional string clusterConfigHash = 3;
- getClusterConfigHash() - Method in class alluxio.wire.ConfigHash
-
- getClusterConfigHash() - Method in class alluxio.wire.WorkerWebUIConfiguration
-
- getClusterConfigHashBytes() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string clusterConfigHash = 1;
- getClusterConfigHashBytes() - Method in class alluxio.grpc.GetConfigHashPResponse
-
optional string clusterConfigHash = 1;
- getClusterConfigHashBytes() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
-
optional string clusterConfigHash = 1;
- getClusterConfigHashBytes() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string clusterConfigHash = 3;
- getClusterConfigHashBytes() - Method in class alluxio.grpc.GetConfigurationPResponse
-
optional string clusterConfigHash = 3;
- getClusterConfigHashBytes() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
optional string clusterConfigHash = 3;
- getClusterConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional int64 clusterConfigLastUpdateTime = 5;
- getClusterConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse
-
optional int64 clusterConfigLastUpdateTime = 5;
- getClusterConfigLastUpdateTime() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
optional int64 clusterConfigLastUpdateTime = 5;
- getClusterConfigLastUpdateTime() - Method in class alluxio.wire.ConfigHash
-
- getClusterConfigLastUpdateTime() - Method in class alluxio.wire.WorkerWebUIConfiguration
-
- getClusterConfigLastUpdateTimeText() - Method in class alluxio.wire.ConfigHash
-
- getClusterConfigs(int) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigs(int) - Method in class alluxio.grpc.GetConfigurationPResponse
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigs(int) - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsBuilder(int) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsBuilderList() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsCount() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsCount() - Method in class alluxio.grpc.GetConfigurationPResponse
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsCount() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsList() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsList() - Method in class alluxio.grpc.GetConfigurationPResponse
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsList() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsOrBuilder(int) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsOrBuilder(int) - Method in class alluxio.grpc.GetConfigurationPResponse
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsOrBuilder(int) - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsOrBuilderList() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsOrBuilderList() - Method in class alluxio.grpc.GetConfigurationPResponse
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfigsOrBuilderList() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- getClusterConfLastUpdateTime() - Method in class alluxio.wire.Configuration
-
- getClusterId() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string clusterId = 11;
- getClusterId() - Method in class alluxio.grpc.MasterInfo
-
optional string clusterId = 11;
- getClusterId() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional string clusterId = 11;
- getClusterID() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getClusterID() - Method in class alluxio.master.meta.DefaultMetaMaster.State
-
- getClusterID() - Method in interface alluxio.master.meta.MetaMaster
-
- getClusterId() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
optional string cluster_id = 1;
- getClusterId() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
optional string cluster_id = 1;
- getClusterId() - Method in interface alluxio.proto.journal.Meta.ClusterInfoEntryOrBuilder
-
optional string cluster_id = 1;
- getClusterId() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets cluster id.
- getClusterIdBytes() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string clusterId = 11;
- getClusterIdBytes() - Method in class alluxio.grpc.MasterInfo
-
optional string clusterId = 11;
- getClusterIdBytes() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional string clusterId = 11;
- getClusterIdBytes() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
optional string cluster_id = 1;
- getClusterIdBytes() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
optional string cluster_id = 1;
- getClusterIdBytes() - Method in interface alluxio.proto.journal.Meta.ClusterInfoEntryOrBuilder
-
optional string cluster_id = 1;
- getClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfoBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfoOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterLimit() - Method in class alluxio.stress.job.StressBenchConfig
-
- getCmd() - Method in class alluxio.shell.CommandReturn
-
Gets the command run.
- getCmdConfig() - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional bytes cmdConfig = 1;
- getCmdConfig() - Method in class alluxio.grpc.SubmitRequest
-
optional bytes cmdConfig = 1;
- getCmdConfig() - Method in interface alluxio.grpc.SubmitRequestOrBuilder
-
optional bytes cmdConfig = 1;
- getCmdProgress() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- getCmdProgress() - Method in class alluxio.grpc.CmdSummary
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- getCmdProgress() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- getCmdProgressBuilder() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- getCmdProgressOrBuilder() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- getCmdProgressOrBuilder() - Method in class alluxio.grpc.CmdSummary
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- getCmdProgressOrBuilder() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- getCmdRunAttempt() - Method in class alluxio.master.job.common.CmdInfo
-
Get CmdRunAttempt.
- getCmdStatus(long) - Method in interface alluxio.client.job.JobMasterClient
-
Gets the status of the given command jobControlId.
- getCmdStatus(long) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- getCmdStatus() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
optional .alluxio.grpc.job.Status cmdStatus = 1;
- getCmdStatus() - Method in class alluxio.grpc.GetCmdStatusResponse
-
optional .alluxio.grpc.job.Status cmdStatus = 1;
- getCmdStatus() - Method in interface alluxio.grpc.GetCmdStatusResponseOrBuilder
-
optional .alluxio.grpc.job.Status cmdStatus = 1;
- getCmdStatus(GetCmdStatusRequest, StreamObserver<GetCmdStatusResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
-
Get status for a CMD job, return a status.
- getCmdStatus(GetCmdStatusRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
-
Get status for a CMD job, return a status.
- getCmdStatus(GetCmdStatusRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
-
Get status for a CMD job, return a status.
- getCmdStatus(GetCmdStatusRequest, StreamObserver<GetCmdStatusResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
-
Get status for a CMD job, return a status.
- getCmdStatus(long) - Method in class alluxio.master.job.JobMaster
-
Get command status.
- getCmdStatus(GetCmdStatusRequest, StreamObserver<GetCmdStatusResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
-
- getCmdStatus(long) - Method in class alluxio.master.job.tracker.CmdJobTracker
-
Get status information for a CMD.
- getCmdStatusBlock() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- getCmdStatusBlock() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- getCmdStatusBlock() - Method in interface alluxio.grpc.GetCmdStatusDetailedResponseOrBuilder
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- getCmdStatusBlock(long) - Method in class alluxio.master.job.tracker.CmdJobTracker
-
Get a cmdStatusBlock information.
- getCmdStatusBlockBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- getCmdStatusBlockOrBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- getCmdStatusBlockOrBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- getCmdStatusBlockOrBuilder() - Method in interface alluxio.grpc.GetCmdStatusDetailedResponseOrBuilder
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- getCmdStatusDetailed(long) - Method in interface alluxio.client.job.JobMasterClient
-
Gets the detailed status of the given command jobControlId.
- getCmdStatusDetailed(long) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- getCmdStatusDetailed(GetCmdStatusDetailedRequest, StreamObserver<GetCmdStatusDetailedResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
-
Get detailed status for a CMD job, return detailed status information.
- getCmdStatusDetailed(GetCmdStatusDetailedRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
-
Get detailed status for a CMD job, return detailed status information.
- getCmdStatusDetailed(GetCmdStatusDetailedRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
-
Get detailed status for a CMD job, return detailed status information.
- getCmdStatusDetailed(GetCmdStatusDetailedRequest, StreamObserver<GetCmdStatusDetailedResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
-
Get detailed status for a CMD job, return detailed status information.
- getCmdStatusDetailed(long) - Method in class alluxio.master.job.JobMaster
-
- getCmdStatusDetailed(GetCmdStatusDetailedRequest, StreamObserver<GetCmdStatusDetailedResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
-
- GetCmdStatusDetailedOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedOptions
- GetCmdStatusDetailedOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedOptions
- GetCmdStatusDetailedOptionsOrBuilder - Interface in alluxio.grpc
-
- GetCmdStatusDetailedRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedRequest
- GetCmdStatusDetailedRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedRequest
- GetCmdStatusDetailedRequestOrBuilder - Interface in alluxio.grpc
-
- GetCmdStatusDetailedResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedResponse
- GetCmdStatusDetailedResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedResponse
- GetCmdStatusDetailedResponseOrBuilder - Interface in alluxio.grpc
-
- GetCmdStatusOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusOptions
- GetCmdStatusOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusOptions
- GetCmdStatusOptionsOrBuilder - Interface in alluxio.grpc
-
- GetCmdStatusRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusRequest
- GetCmdStatusRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusRequest
- GetCmdStatusRequestOrBuilder - Interface in alluxio.grpc
-
- GetCmdStatusResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusResponse
- GetCmdStatusResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetCmdStatusResponse
- GetCmdStatusResponseOrBuilder - Interface in alluxio.grpc
-
- getCode() - Method in enum alluxio.cli.fsadmin.command.DecommissionWorkerCommand.ReturnCode
-
Gets the code.
- getCode() - Method in class alluxio.grpc.BlockStatus.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in class alluxio.grpc.BlockStatus
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in interface alluxio.grpc.BlockStatusOrBuilder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in class alluxio.grpc.FileFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in class alluxio.grpc.FileFailure
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in interface alluxio.grpc.FileFailureOrBuilder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in class alluxio.grpc.LoadFileFailure
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in class alluxio.grpc.RouteFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in class alluxio.grpc.RouteFailure
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- getCode() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- getCode() - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
-
- getCode() - Method in class alluxio.s3.S3Error
-
- getCode() - Method in class alluxio.s3.S3ErrorCode
-
- getCollectionCount() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
-
- getCollectionTime() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
-
- getColName() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_name = 1;
- getColName() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional string col_name = 1;
- getColName() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional string col_name = 1;
- getColNameBytes() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_name = 1;
- getColNameBytes() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional string col_name = 1;
- getColNameBytes() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional string col_name = 1;
- getColNames(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- getColNames(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
repeated string col_names = 3;
- getColNames(int) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
repeated string col_names = 3;
- getColNames(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- getColNames(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
repeated string col_names = 3;
- getColNames(int) - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
-
repeated string col_names = 3;
- getColNamesBytes(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- getColNamesBytes(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
repeated string col_names = 3;
- getColNamesBytes(int) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
repeated string col_names = 3;
- getColNamesBytes(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- getColNamesBytes(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
repeated string col_names = 3;
- getColNamesBytes(int) - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
-
repeated string col_names = 3;
- getColNamesCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- getColNamesCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
repeated string col_names = 3;
- getColNamesCount() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
repeated string col_names = 3;
- getColNamesCount() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- getColNamesCount() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
repeated string col_names = 3;
- getColNamesCount() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
-
repeated string col_names = 3;
- getColNamesList() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- getColNamesList() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
repeated string col_names = 3;
- getColNamesList() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
repeated string col_names = 3;
- getColNamesList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- getColNamesList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
repeated string col_names = 3;
- getColNamesList() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
-
repeated string col_names = 3;
- getCols(int) - Method in class alluxio.grpc.table.Schema.Builder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getCols(int) - Method in class alluxio.grpc.table.Schema
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getCols(int) - Method in interface alluxio.grpc.table.SchemaOrBuilder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsBuilder(int) - Method in class alluxio.grpc.table.Schema.Builder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsBuilderList() - Method in class alluxio.grpc.table.Schema.Builder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsCount() - Method in class alluxio.grpc.table.Schema.Builder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsCount() - Method in class alluxio.grpc.table.Schema
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsCount() - Method in interface alluxio.grpc.table.SchemaOrBuilder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsList() - Method in class alluxio.grpc.table.Schema.Builder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsList() - Method in class alluxio.grpc.table.Schema
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsList() - Method in interface alluxio.grpc.table.SchemaOrBuilder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsOrBuilder(int) - Method in class alluxio.grpc.table.Schema.Builder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsOrBuilder(int) - Method in class alluxio.grpc.table.Schema
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsOrBuilder(int) - Method in interface alluxio.grpc.table.SchemaOrBuilder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsOrBuilderList() - Method in class alluxio.grpc.table.Schema.Builder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsOrBuilderList() - Method in class alluxio.grpc.table.Schema
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColsOrBuilderList() - Method in interface alluxio.grpc.table.SchemaOrBuilder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- getColType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_type = 2;
- getColType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional string col_type = 2;
- getColType() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional string col_type = 2;
- getColTypeBytes() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_type = 2;
- getColTypeBytes() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional string col_type = 2;
- getColTypeBytes() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional string col_type = 2;
- getColumn() - Method in class alluxio.grpc.table.FileStatistics.Builder
-
Deprecated.
- getColumn() - Method in class alluxio.grpc.table.FileStatistics
-
Deprecated.
- getColumn() - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
-
Deprecated.
- getColumnConstraints() - Method in class alluxio.grpc.table.Constraint.Builder
-
Deprecated.
- getColumnConstraints() - Method in class alluxio.grpc.table.Constraint
-
Deprecated.
- getColumnConstraints() - Method in interface alluxio.grpc.table.ConstraintOrBuilder
-
Deprecated.
- getColumnConstraintsCount() - Method in class alluxio.grpc.table.Constraint.Builder
-
- getColumnConstraintsCount() - Method in class alluxio.grpc.table.Constraint
-
- getColumnConstraintsCount() - Method in interface alluxio.grpc.table.ConstraintOrBuilder
-
maps column to constraint, columns not present are not constrained
- getColumnConstraintsMap() - Method in class alluxio.grpc.table.Constraint.Builder
-
maps column to constraint, columns not present are not constrained
- getColumnConstraintsMap() - Method in class alluxio.grpc.table.Constraint
-
maps column to constraint, columns not present are not constrained
- getColumnConstraintsMap() - Method in interface alluxio.grpc.table.ConstraintOrBuilder
-
maps column to constraint, columns not present are not constrained
- getColumnConstraintsOrDefault(String, Domain) - Method in class alluxio.grpc.table.Constraint.Builder
-
maps column to constraint, columns not present are not constrained
- getColumnConstraintsOrDefault(String, Domain) - Method in class alluxio.grpc.table.Constraint
-
maps column to constraint, columns not present are not constrained
- getColumnConstraintsOrDefault(String, Domain) - Method in interface alluxio.grpc.table.ConstraintOrBuilder
-
maps column to constraint, columns not present are not constrained
- getColumnConstraintsOrThrow(String) - Method in class alluxio.grpc.table.Constraint.Builder
-
maps column to constraint, columns not present are not constrained
- getColumnConstraintsOrThrow(String) - Method in class alluxio.grpc.table.Constraint
-
maps column to constraint, columns not present are not constrained
- getColumnConstraintsOrThrow(String) - Method in interface alluxio.grpc.table.ConstraintOrBuilder
-
maps column to constraint, columns not present are not constrained
- getColumnCount() - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- getColumnCount() - Method in class alluxio.grpc.table.FileStatistics
-
- getColumnCount() - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
-
map column names to column statistics
- getColumnMap() - Method in class alluxio.grpc.table.FileStatistics.Builder
-
map column names to column statistics
- getColumnMap() - Method in class alluxio.grpc.table.FileStatistics
-
map column names to column statistics
- getColumnMap() - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
-
map column names to column statistics
- getColumnName() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
required string column_name = 1;
- getColumnName() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
-
required string column_name = 1;
- getColumnName() - Method in interface alluxio.grpc.table.layout.hive.SortingColumnOrBuilder
-
required string column_name = 1;
- getColumnNameBytes() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
required string column_name = 1;
- getColumnNameBytes() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
-
required string column_name = 1;
- getColumnNameBytes() - Method in interface alluxio.grpc.table.layout.hive.SortingColumnOrBuilder
-
required string column_name = 1;
- getColumnOrDefault(String, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.FileStatistics.Builder
-
map column names to column statistics
- getColumnOrDefault(String, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.FileStatistics
-
map column names to column statistics
- getColumnOrDefault(String, ColumnStatisticsInfo) - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
-
map column names to column statistics
- getColumnOrThrow(String) - Method in class alluxio.grpc.table.FileStatistics.Builder
-
map column names to column statistics
- getColumnOrThrow(String) - Method in class alluxio.grpc.table.FileStatistics
-
map column names to column statistics
- getColumnOrThrow(String) - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
-
map column names to column statistics
- getCommand() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
optional .alluxio.grpc.Command command = 1;
- getCommand() - Method in class alluxio.grpc.BlockHeartbeatPResponse
-
optional .alluxio.grpc.Command command = 1;
- getCommand() - Method in interface alluxio.grpc.BlockHeartbeatPResponseOrBuilder
-
optional .alluxio.grpc.Command command = 1;
- getCommand() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- getCommand() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- getCommand() - Method in interface alluxio.grpc.FileSystemHeartbeatPResponseOrBuilder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- getCommand() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
- getCommand() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
-
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
- getCommand() - Method in interface alluxio.grpc.JobMasterHeartbeatPResponseOrBuilder
-
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
- getCommand() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
optional .alluxio.grpc.meta.MetaCommand command = 1;
- getCommand() - Method in class alluxio.grpc.MasterHeartbeatPResponse
-
optional .alluxio.grpc.meta.MetaCommand command = 1;
- getCommand() - Method in interface alluxio.grpc.MasterHeartbeatPResponseOrBuilder
-
optional .alluxio.grpc.meta.MetaCommand command = 1;
- getCommand() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommand() - Method in class alluxio.grpc.WriteRequest
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommand() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommand() - Method in class alluxio.shell.ShellCommand
-
Gets the command.
- getCommandBuilder() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
optional .alluxio.grpc.Command command = 1;
- getCommandBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- getCommandBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
-
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectConfigCommand
-
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectEnvCommand
-
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectJvmInfoCommand
-
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectLogCommand
-
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectMetricsCommand
-
- getCommandName() - Method in interface alluxio.cli.Command
-
Gets the command name as input from the shell.
- getCommandName() - Method in class alluxio.cli.command.metadatacache.DropAllCommand
-
- getCommandName() - Method in class alluxio.cli.command.metadatacache.DropCommand
-
- getCommandName() - Method in class alluxio.cli.command.metadatacache.SizeCommand
-
- getCommandName() - Method in class alluxio.cli.command.MetadataCacheCommand
-
- getCommandName() - Method in class alluxio.cli.extensions.command.InstallCommand
-
- getCommandName() - Method in class alluxio.cli.extensions.command.LsCommand
-
- getCommandName() - Method in class alluxio.cli.extensions.command.UninstallCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.CatCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.CheckCachedCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.ChecksumCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.ChgrpCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.ChmodCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.ChownCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.CpCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.FreeCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.HeadCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.HelpCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.LoadCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.LocationCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.LsCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.MkdirCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.MvCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.RmCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.StatCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.TailCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.TestCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.TouchCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.command.BackupCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.command.EnableWorkerCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.command.JournalCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.command.MetricsCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.command.NodesCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.command.ReportCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.nodes.WorkerStatusCommand
-
- getCommandOptions() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- getCommandOptions() - Method in class alluxio.grpc.FileSystemCommand
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- getCommandOptions() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- getCommandOptions() - Method in class alluxio.wire.FileSystemCommand
-
- getCommandOptionsBuilder() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- getCommandOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- getCommandOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemCommand
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- getCommandOptionsOrBuilder() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- getCommandOrBuilder() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
optional .alluxio.grpc.Command command = 1;
- getCommandOrBuilder() - Method in class alluxio.grpc.BlockHeartbeatPResponse
-
optional .alluxio.grpc.Command command = 1;
- getCommandOrBuilder() - Method in interface alluxio.grpc.BlockHeartbeatPResponseOrBuilder
-
optional .alluxio.grpc.Command command = 1;
- getCommandOrBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- getCommandOrBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- getCommandOrBuilder() - Method in interface alluxio.grpc.FileSystemHeartbeatPResponseOrBuilder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- getCommandOrBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommandOrBuilder() - Method in class alluxio.grpc.WriteRequest
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommandOrBuilder() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommands() - Method in class alluxio.cli.AbstractShell
-
- getCommands(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommands(int) - Method in class alluxio.grpc.JobHeartbeatPResponse
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommands(int) - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsBuilderList() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsCount() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsCount() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsCount() - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsList() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsList() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsList() - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPResponse
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilder(int) - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilderList() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilderList() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilderList() - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandType() - Method in class alluxio.grpc.Command.Builder
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in class alluxio.grpc.Command
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in interface alluxio.grpc.CommandOrBuilder
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in class alluxio.grpc.FileSystemCommand
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in class alluxio.wire.FileSystemCommand
-
- getComment() - Method in class alluxio.grpc.table.Database.Builder
-
optional string comment = 7;
- getComment() - Method in class alluxio.grpc.table.Database
-
optional string comment = 7;
- getComment() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string comment = 7;
- getComment() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string comment = 4;
- getComment() - Method in class alluxio.grpc.table.FieldSchema
-
optional string comment = 4;
- getComment() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional string comment = 4;
- getCommentBytes() - Method in class alluxio.grpc.table.Database.Builder
-
optional string comment = 7;
- getCommentBytes() - Method in class alluxio.grpc.table.Database
-
optional string comment = 7;
- getCommentBytes() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string comment = 7;
- getCommentBytes() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string comment = 4;
- getCommentBytes() - Method in class alluxio.grpc.table.FieldSchema
-
optional string comment = 4;
- getCommentBytes() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional string comment = 4;
- getCommitBlockMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
-
- getCommitPath() - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- getCommittedBytes() - Method in interface alluxio.worker.block.meta.StorageDir
-
Gets the total size of committed blocks in this StorageDir in bytes.
- getCommonOptions() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.CheckConsistencyPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptions() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.DeletePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.ExistsPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.FreePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.GetNewBlockIdForFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.MountPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.RenamePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.SetAclPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in class alluxio.grpc.UnmountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.UnmountPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.UnmountPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.proto.client.Cache.PRocksPageStoreOptionsOrBuilder
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.UnmountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckAccessPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CheckConsistencyPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.DeletePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ExistsPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.FreePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.GetNewBlockIdForFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetStatusPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.MountPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.OpenFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.RenamePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAclPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAttributePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.UnmountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.UnmountPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.UnmountPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.proto.client.Cache.PRocksPageStoreOptionsOrBuilder
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- getCommonPoolParallelism() - Static method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns the targeted parallelism level of the common pool.
- getCommonPrefixes() - Method in class alluxio.s3.ListBucketResult
-
- getCommonPrefixes() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
-
Use common prefixes to infer pseudo-directories in object store.
- getCommonPrefixes() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunk
-
- getCommonPrefixes() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunkV1
-
- getCompleted() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool completed = 8;
- getCompleted() - Method in class alluxio.grpc.FileInfo
-
optional bool completed = 8;
- getCompleted() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool completed = 8;
- getCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool completed = 10;
- getCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional bool completed = 10;
- getCompleted() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional bool completed = 10;
- getCompleted() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional bool completed = 4;
- getCompleted() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional bool completed = 4;
- getCompleted() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional bool completed = 4;
- getCompletedCmdCount() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
-
Gets the number of completed commands.
- getCompletedCount() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
-
Gets the number of completed jobs.
- getCompletedLocation() - Method in class alluxio.master.journalv0.ufs.UfsJournal
-
- getCompletedLog(long) - Method in class alluxio.master.journalv0.ufs.UfsJournal
-
- getCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleteFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleteFileMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getCompleteFileMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getCompleteFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleteFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleteFileOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleter() - Method in class alluxio.concurrent.jsr.CountedCompleter
-
Returns the completer established in this task's constructor, or null
if none.
- GetConf - Class in alluxio.cli
-
Utility for printing Alluxio configuration.
- getConf(ClientContext, String...) - Static method in class alluxio.cli.GetConf
-
Implements get configuration.
- getConf() - Method in class alluxio.client.file.cache.LocalCacheFileSystem
-
- getConf() - Method in class alluxio.client.file.DelegatingFileSystem
-
- getConf() - Method in interface alluxio.client.file.FileSystem
-
- getConf() - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- getConf() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- getConf() - Method in class alluxio.multi.process.BaseMaster
-
- getConfAddress() - Method in class alluxio.AbstractClient
-
- getConfAddress() - Method in class alluxio.AbstractJobMasterClient
-
- getConfAddress() - Method in class alluxio.AbstractMasterClient
-
- getConfAddress() - Method in interface alluxio.Client
-
- getConfigCheckErrorNum() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets config check error num.
- getConfigCheckErrors() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets config check errors.
- getConfigCheckReport() - Method in class alluxio.master.meta.checkconf.ConfigurationChecker
-
- getConfigCheckReport() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getConfigCheckReport() - Method in interface alluxio.master.meta.MetaMaster
-
- getConfigCheckStatus() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets config check status.
- getConfigCheckWarnNum() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets config check warn num.
- getConfigCheckWarns() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets config check warns.
- getConfigErrors() - Method in class alluxio.wire.ConfigCheckReport
-
- getConfigHash() - Method in interface alluxio.client.meta.MetaMasterConfigClient
-
- getConfigHash() - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
-
- getConfigHash(GetConfigHashPOptions, StreamObserver<GetConfigHashPResponse>) - Method in interface alluxio.grpc.MetaMasterConfigurationServiceGrpc.AsyncService
-
Returns the hashes of cluster and path level configurations.
- getConfigHash(GetConfigHashPOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceBlockingStub
-
Returns the hashes of cluster and path level configurations.
- getConfigHash(GetConfigHashPOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub
-
Returns the hashes of cluster and path level configurations.
- getConfigHash(GetConfigHashPOptions, StreamObserver<GetConfigHashPResponse>) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub
-
Returns the hashes of cluster and path level configurations.
- getConfigHash() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getConfigHash() - Method in interface alluxio.master.meta.MetaMaster
-
- getConfigHash(GetConfigHashPOptions, StreamObserver<GetConfigHashPResponse>) - Method in class alluxio.master.meta.MetaMasterConfigurationServiceHandler
-
- getConfigHash() - Method in class alluxio.wire.MasterWebUIConfiguration
-
- GetConfigHashPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigHashPOptions
- GetConfigHashPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigHashPOptions
- GetConfigHashPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetConfigHashPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigHashPResponse
- GetConfigHashPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigHashPResponse
- GetConfigHashPResponseOrBuilder - Interface in alluxio.grpc
-
- getConfigReport() - Method in interface alluxio.client.meta.MetaMasterClient
-
Gets the server-side configuration check report.
- getConfigReport() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
-
- getConfigReport(GetConfigReportPOptions, StreamObserver<GetConfigReportPResponse>) - Method in interface alluxio.grpc.MetaMasterClientServiceGrpc.AsyncService
-
Returns server-side configuration report.
- getConfigReport(GetConfigReportPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
-
Returns server-side configuration report.
- getConfigReport(GetConfigReportPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
-
Returns server-side configuration report.
- getConfigReport(GetConfigReportPOptions, StreamObserver<GetConfigReportPResponse>) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
-
Returns server-side configuration report.
- getConfigReport(GetConfigReportPOptions, StreamObserver<GetConfigReportPResponse>) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
-
- GetConfigReportPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigReportPOptions
- GetConfigReportPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigReportPOptions
- GetConfigReportPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetConfigReportPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigReportPResponse
- GetConfigReportPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigReportPResponse
- GetConfigReportPResponseOrBuilder - Interface in alluxio.grpc
-
- getConfigs(int) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigs(int) - Method in class alluxio.grpc.RegisterMasterPOptions
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigs(int) - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigs(int) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigs(int) - Method in class alluxio.grpc.RegisterWorkerPOptions
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigs(int) - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsBuilder(int) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsBuilderList() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsBuilderList() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsCount() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsCount() - Method in class alluxio.grpc.RegisterMasterPOptions
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsCount() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsCount() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsCount() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsCount() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsList() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsList() - Method in class alluxio.grpc.RegisterMasterPOptions
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsList() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsList() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsList() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsList() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilder(int) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilder(int) - Method in class alluxio.grpc.RegisterMasterPOptions
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilder(int) - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPOptions
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilder(int) - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilderList() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilderList() - Method in class alluxio.grpc.RegisterMasterPOptions
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilderList() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilderList() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilderList() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigsOrBuilderList() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- getConfigStatus() - Method in class alluxio.wire.ConfigCheckReport
-
- getConfiguration(GetConfigurationPOptions) - Method in interface alluxio.client.meta.MetaMasterConfigClient
-
- getConfiguration(GetConfigurationPOptions) - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
-
- getConfiguration() - Method in class alluxio.common.RpcPortHealthCheckClient
-
- getConfiguration() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getConfiguration(Scope) - Static method in class alluxio.conf.Configuration
-
Gets all configuration properties filtered by the specified scope.
- getConfiguration() - Method in class alluxio.grpc.GrpcChannelBuilder
-
- getConfiguration(GetConfigurationPOptions, StreamObserver<GetConfigurationPResponse>) - Method in interface alluxio.grpc.MetaMasterConfigurationServiceGrpc.AsyncService
-
Returns a list of Alluxio runtime configuration information.
- getConfiguration(GetConfigurationPOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceBlockingStub
-
Returns a list of Alluxio runtime configuration information.
- getConfiguration(GetConfigurationPOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub
-
Returns a list of Alluxio runtime configuration information.
- getConfiguration(GetConfigurationPOptions, StreamObserver<GetConfigurationPResponse>) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub
-
Returns a list of Alluxio runtime configuration information.
- getConfiguration(GetConfigurationPOptions) - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getConfiguration(GetConfigurationPOptions) - Method in interface alluxio.master.meta.MetaMaster
-
- getConfiguration(GetConfigurationPOptions, StreamObserver<GetConfigurationPResponse>) - Method in class alluxio.master.meta.MetaMasterConfigurationServiceHandler
-
- getConfiguration() - Method in class alluxio.underfs.BaseUnderFileSystem
-
- getConfiguration() - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the under file system configuration.
- getConfiguration() - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getConfiguration() - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- getConfiguration() - Method in class alluxio.wire.AlluxioJobWorkerInfo
-
- getConfiguration() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getConfiguration() - Method in class alluxio.wire.AlluxioProxyInfo
-
- getConfiguration() - Method in class alluxio.wire.AlluxioWorkerInfo
-
- getConfiguration() - Method in class alluxio.wire.MasterWebUIConfiguration
-
Gets configuration.
- getConfiguration() - Method in class alluxio.wire.WorkerWebUIConfiguration
-
Gets configuration.
- getConfiguration(GetConfigurationPOptions) - Method in interface alluxio.worker.block.BlockWorker
-
- getConfigurationFromHadoop(Configuration) - Static method in class alluxio.hadoop.HadoopConfigurationUtils
-
Extracts relevant configuration from Hadoop Configuration
.
- getConfigurationFromUri(URI, Configuration) - Method in class alluxio.hadoop.AbstractFileSystem
-
Gets the connection configuration from the input uri.
- getConfigurationFromUri(URI, Configuration) - Method in class alluxio.hadoop.FileSystem
-
- GetConfigurationPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigurationPOptions
- GetConfigurationPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigurationPOptions
- GetConfigurationPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetConfigurationPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigurationPResponse
- GetConfigurationPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetConfigurationPResponse
- GetConfigurationPResponseOrBuilder - Interface in alluxio.grpc
-
- getConfigWarns() - Method in class alluxio.wire.ConfigCheckReport
-
- getConfImpl(Supplier<RetryHandlingMetaMasterConfigClient>, AlluxioConfiguration, String...) - Static method in class alluxio.cli.GetConf
-
Implements get configuration.
- getConfMap() - Method in class alluxio.master.meta.checkconf.ConfigurationStore
-
- getConfMasterInquireClient() - Method in class alluxio.master.MasterClientContext
-
- getConfMasterInquireClient() - Method in class alluxio.worker.job.JobMasterClientContext
-
- getConnectAddress(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Helper method to get the
InetSocketAddress
address for client to communicate with the
service.
- getConnectAddress() - Method in class alluxio.worker.DataServerFactory
-
Get gRPC connect address.
- getConnectDetails(AlluxioConfiguration) - Static method in class alluxio.master.MasterInquireClient.Factory
-
- getConnectDetails() - Method in interface alluxio.master.MasterInquireClient
-
Returns canonical connect details representing how this client connects to the master.
- getConnectDetails() - Method in class alluxio.master.PollingMasterInquireClient
-
- getConnectDetails() - Method in class alluxio.master.SingleMasterInquireClient
-
- getConnectDetails() - Method in class alluxio.master.ZkMasterInquireClient
-
- getConnectHost(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Provides an externally resolvable hostname for client to communicate with the service.
- getConnection() - Method in class alluxio.master.backup.BackupHandshakeMessage
-
- getConnectionUser(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
-
Gets the connection user name from the
ThreadLocal
variable.
- getConnectionUserName() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
-
- getConnectMethod() - Static method in class alluxio.grpc.MessagingServiceGrpc
-
- getConsistencyLevel() - Method in class alluxio.conf.PropertyKey
-
- getConstraint() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- getConstraint() - Method in class alluxio.grpc.table.ReadTablePRequest
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- getConstraint() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- getConstraintBuilder() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- getConstraintOrBuilder() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- getConstraintOrBuilder() - Method in class alluxio.grpc.table.ReadTablePRequest
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- getConstraintOrBuilder() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- getContainerHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string containerHost = 7;
- getContainerHost() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string containerHost = 7;
- getContainerHost() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string containerHost = 7;
- getContainerHost() - Method in class alluxio.wire.WorkerNetAddress
-
- getContainerHostBytes() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string containerHost = 7;
- getContainerHostBytes() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string containerHost = 7;
- getContainerHostBytes() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string containerHost = 7;
- getContainerId(long) - Static method in class alluxio.master.block.BlockId
-
- getContainerId() - Method in class alluxio.master.file.state.DirectoryId
-
- getContainerId() - Method in interface alluxio.master.file.state.DirectoryId.UnmodifiableDirectoryId
-
- getContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
optional int64 container_id = 1;
- getContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
optional int64 container_id = 1;
- getContainerId() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
-
optional int64 container_id = 1;
- getContentHash() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional string contentHash = 4;
- getContentHash() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional string contentHash = 4;
- getContentHash() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional string contentHash = 4;
- getContentHash() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string contentHash = 34;
- getContentHash() - Method in class alluxio.grpc.FileInfo
-
optional string contentHash = 34;
- getContentHash() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string contentHash = 34;
- getContentHash() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional string content_hash = 1;
- getContentHash() - Method in class alluxio.grpc.UfsFileStatus
-
optional string content_hash = 1;
- getContentHash() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
-
optional string content_hash = 1;
- getContentHash() - Method in class alluxio.grpc.WriteResponse.Builder
-
Errors will be handled by standard gRPC stream APIs.
- getContentHash() - Method in class alluxio.grpc.WriteResponse
-
Errors will be handled by standard gRPC stream APIs.
- getContentHash() - Method in interface alluxio.grpc.WriteResponseOrBuilder
-
Errors will be handled by standard gRPC stream APIs.
- getContentHash() - Method in class alluxio.underfs.AtomicFileOutputStream
-
- getContentHash() - Method in interface alluxio.underfs.ContentHashable
-
- getContentHash() - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
-
- getContentHash() - Method in class alluxio.underfs.cos.COSOutputStream
-
- getContentHash() - Method in class alluxio.underfs.gcs.GCSOutputStream
-
- getContentHash() - Method in class alluxio.underfs.gcs.v2.GCSV2OutputStream
-
- getContentHash() - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
-
- getContentHash() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
-
- getContentHash() - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
-
- getContentHash() - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
-
- getContentHash() - Method in class alluxio.underfs.obs.OBSOutputStream
-
- getContentHash() - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
-
- getContentHash() - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
-
- getContentHash() - Method in class alluxio.underfs.oss.OSSOutputStream
-
- getContentHash() - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
-
- getContentHash() - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
-
- getContentHash() - Method in class alluxio.underfs.s3a.S3AOutputStream
-
- getContentHash() - Method in class alluxio.underfs.UfsFileStatus
-
- getContentHash() - Method in class alluxio.wire.FileInfo
-
- getContentHash() - Method in class alluxio.worker.grpc.WriteRequestContext
-
- getContentHashBytes() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional string contentHash = 4;
- getContentHashBytes() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional string contentHash = 4;
- getContentHashBytes() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional string contentHash = 4;
- getContentHashBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string contentHash = 34;
- getContentHashBytes() - Method in class alluxio.grpc.FileInfo
-
optional string contentHash = 34;
- getContentHashBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string contentHash = 34;
- getContentHashBytes() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional string content_hash = 1;
- getContentHashBytes() - Method in class alluxio.grpc.UfsFileStatus
-
optional string content_hash = 1;
- getContentHashBytes() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
-
optional string content_hash = 1;
- getContentHashBytes() - Method in class alluxio.grpc.WriteResponse.Builder
-
Errors will be handled by standard gRPC stream APIs.
- getContentHashBytes() - Method in class alluxio.grpc.WriteResponse
-
Errors will be handled by standard gRPC stream APIs.
- getContentHashBytes() - Method in interface alluxio.grpc.WriteResponseOrBuilder
-
Errors will be handled by standard gRPC stream APIs.
- getContentLength() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional int64 content_length = 2;
- getContentLength() - Method in class alluxio.grpc.UfsFileStatus
-
optional int64 content_length = 2;
- getContentLength() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
-
optional int64 content_length = 2;
- getContentLength() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
-
Gets the size of object contents in bytes.
- getContentLength() - Method in class alluxio.underfs.UfsFileStatus
-
Get the content size in bytes.
- getContents() - Method in class alluxio.s3.ListBucketResult
-
- getContext() - Method in class alluxio.client.file.dora.DoraCacheClient
-
Get Context.
- getContext() - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- getContext() - Method in interface alluxio.jnifuse.FuseFileSystem
-
- getContext() - Method in class alluxio.master.transport.GrpcMessagingThread
-
- getContext(Class<?>) - Method in class alluxio.web.JacksonProtobufObjectMapperProvider
-
- getContext() - Method in class alluxio.worker.s3.S3NettyHandler
-
Get the channel context of this request.
- getContinuationToken() - Method in class alluxio.s3.ListBucketOptions
-
- getContinuationToken() - Method in class alluxio.s3.ListBucketResult
-
- getContinuationToken() - Method in class alluxio.underfs.UfsLoadResult
-
- getCoordinator(long) - Method in class alluxio.master.job.plan.PlanTracker
-
- getCopyJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- getCopyJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- getCopyJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- getCopyJobBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- getCopyJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- getCopyJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- getCopyJobOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- getCopyMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getCount() - Method in class alluxio.grpc.StatusSummary.Builder
-
optional int64 count = 2;
- getCount() - Method in class alluxio.grpc.StatusSummary
-
optional int64 count = 2;
- getCount() - Method in interface alluxio.grpc.StatusSummaryOrBuilder
-
optional int64 count = 2;
- getCount() - Method in class alluxio.job.wire.StatusSummary
-
Returns the count of the number of jobs associated with
Status
.
- getCounter() - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- getCounter() - Method in class alluxio.worker.grpc.WriteRequestContext
-
- getCounter() - Method in class alluxio.worker.netty.ReadRequestContext
-
- getCounter() - Method in class alluxio.worker.netty.WriteRequestContext
-
- getCounters() - Method in class alluxio.util.BucketCounter
-
- getCpuLoadAverage() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter.JobWorkerHealthReport
-
Returns the system load average of the worker.
- getCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional bool createAncestors = 2;
- getCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional bool createAncestors = 2;
- getCreateAncestors() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional bool createAncestors = 2;
- getCreatedAt() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional int64 created_at = 3;
- getCreatedAt() - Method in class alluxio.grpc.PolicyInfo
-
optional int64 created_at = 3;
- getCreatedAt() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
-
optional int64 created_at = 3;
- getCreatedAt() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional int64 created_at = 3;
- getCreatedAt() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
optional int64 created_at = 3;
- getCreatedAt() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
-
optional int64 created_at = 3;
- getCreateDirectoryMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getCreateDirectoryMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getCreatedTimestamp() - Method in class alluxio.client.file.cache.PageInfo
-
- getCreateFileMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getCreateFileMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getCreateOptions() - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
-
- getCreateOptions() - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
-
- getCreateParent() - Method in class alluxio.underfs.options.CreateOptions
-
- getCreateParent() - Method in class alluxio.underfs.options.MkdirsOptions
-
- getCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- getCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- getCreateUfsFileOptions() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- getCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for ufs writes.
- getCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
This is only applicable for ufs writes.
- getCreateUfsFileOptions() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
This is only applicable for ufs writes.
- getCreateUfsFileOptions() - Method in class alluxio.worker.grpc.UfsFileWriteRequest
-
- getCreateUfsFileOptions() - Method in class alluxio.worker.netty.UfsFileWriteRequest
-
- getCreateUfsFileOptionsBuilder() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- getCreateUfsFileOptionsBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for ufs writes.
- getCreateUfsFileOptionsOrBuilder() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- getCreateUfsFileOptionsOrBuilder() - Method in class alluxio.grpc.WriteRequestCommand
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- getCreateUfsFileOptionsOrBuilder() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- getCreateUfsFileOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for ufs writes.
- getCreateUfsFileOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
This is only applicable for ufs writes.
- getCreateUfsFileOptionsOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
This is only applicable for ufs writes.
- getCreationDate() - Method in class alluxio.s3.ListAllMyBucketsResult.Bucket
-
- getCreationTime() - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Returns the job creation time.
- getCreationTime() - Method in class alluxio.util.webui.UIFileInfo
-
Gets creation time.
- getCreationTimeMs() - Method in class alluxio.client.file.URIStatus
-
- getCreationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 creationTimeMs = 7;
- getCreationTimeMs() - Method in class alluxio.grpc.FileInfo
-
optional int64 creationTimeMs = 7;
- getCreationTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 creationTimeMs = 7;
- getCreationTimeMs() - Method in class alluxio.master.file.meta.Inode
-
- getCreationTimeMs() - Method in interface alluxio.master.file.meta.InodeView
-
- getCreationTimeMs() - Method in class alluxio.master.file.meta.MutableInode
-
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 creation_time_ms = 2;
- getCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 creation_time_ms = 2;
- getCreationTimeMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 creation_time_ms = 2;
- getCreationTimeMs() - Method in class alluxio.wire.FileInfo
-
- getCredentials() - Static method in class alluxio.conf.CredentialPropertyKeys
-
return CREDENTIAL set.
- getCredentialScope() - Method in class alluxio.s3.signature.SignatureInfo
-
- getCurrentBlockCount() - Method in class alluxio.master.job.LoadJob
-
Get the processed block count in the current loading pass.
- getCurrentBlocks(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocks(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocks(int) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksBuilderList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksList() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksList() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
Deprecated.
- getCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
Deprecated.
- getCurrentBlocksOnTiers() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
Deprecated.
- getCurrentBlocksOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- getCurrentBlocksOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
- getCurrentBlocksOnTiersCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersMap() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrDefault(String, TierList) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrDefault(String, TierList) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrDefault(String, TierList) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrThrow(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOrBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOrBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOrBuilder(int) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOrBuilderList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOrBuilderList() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOrBuilderList() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentDirectory() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets current directory.
- getCurrentGroup() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- getCurrentLog(UfsJournal) - Static method in class alluxio.master.journal.ufs.UfsJournalSnapshot
-
Gets the current log (the incomplete log) that is being written to.
- getCurrentLog() - Method in class alluxio.master.journalv0.ufs.UfsJournal
-
- getCurrentMs() - Static method in class alluxio.util.CommonUtils
-
- getCurrentPath() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets current path.
- getCurrentPath() - Method in class alluxio.wire.MasterWebUILogs
-
Gets current path.
- getCurrentPath() - Method in class alluxio.wire.WorkerWebUILogs
-
Gets current path.
- getCurrentSequenceNumbers() - Method in interface alluxio.master.journal.JournalSystem
-
Used to get the current state from a leader journal system.
- getCurrentSequenceNumbers() - Method in class alluxio.master.journal.noop.NoopJournalSystem
-
- getCurrentSequenceNumbers() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- getCurrentSequenceNumbers() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
-
- getCurrentStatus() - Method in class alluxio.master.backup.BackupTracker
-
- getCurrentThreadIdentifier() - Static method in class alluxio.util.ThreadUtils
-
- getCustomProvider() - Method in class alluxio.security.authentication.plain.CustomAuthenticationProvider
-
- getData() - Method in class alluxio.grpc.Chunk.Builder
-
optional bytes data = 1;
- getData() - Method in class alluxio.grpc.Chunk
-
optional bytes data = 1;
- getData() - Method in interface alluxio.grpc.ChunkOrBuilder
-
optional bytes data = 1;
- getData(int) - Method in class alluxio.grpc.Command.Builder
-
repeated int64 data = 2;
- getData(int) - Method in class alluxio.grpc.Command
-
repeated int64 data = 2;
- getData(int) - Method in interface alluxio.grpc.CommandOrBuilder
-
repeated int64 data = 2;
- getData() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- getData() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
Deprecated.
- getData() - Method in interface alluxio.grpc.DownloadSnapshotPResponseOrBuilder
-
Deprecated.
- getData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getData() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getData() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- getData() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
Deprecated.
- getData() - Method in interface alluxio.grpc.UploadSnapshotPRequestOrBuilder
-
Deprecated.
- getData() - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
-
- getDatabase() - Method in class alluxio.client.hive.HiveCacheContext
-
- getDatabase(String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getDatabase(String) - Method in interface alluxio.client.table.TableMasterClient
-
Get database metadata.
- getDatabase(int) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
repeated string database = 1;
- getDatabase(int) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
repeated string database = 1;
- getDatabase(int) - Method in interface alluxio.grpc.table.GetAllDatabasesPResponseOrBuilder
-
repeated string database = 1;
- getDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
optional string database = 1;
- getDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest
-
optional string database = 1;
- getDatabase() - Method in interface alluxio.grpc.table.GetAllTablesPRequestOrBuilder
-
optional string database = 1;
- getDatabase(GetDatabasePRequest, StreamObserver<GetDatabasePResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
-
Gets a database by name from the table master
- getDatabase(GetDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
-
Gets a database by name from the table master
- getDatabase(GetDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
-
Gets a database by name from the table master
- getDatabase(GetDatabasePRequest, StreamObserver<GetDatabasePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
-
Gets a database by name from the table master
- getDatabaseBytes(int) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
repeated string database = 1;
- getDatabaseBytes(int) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
repeated string database = 1;
- getDatabaseBytes(int) - Method in interface alluxio.grpc.table.GetAllDatabasesPResponseOrBuilder
-
repeated string database = 1;
- getDatabaseBytes() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
optional string database = 1;
- getDatabaseBytes() - Method in class alluxio.grpc.table.GetAllTablesPRequest
-
optional string database = 1;
- getDatabaseBytes() - Method in interface alluxio.grpc.table.GetAllTablesPRequestOrBuilder
-
optional string database = 1;
- getDatabaseCount() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
repeated string database = 1;
- getDatabaseCount() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
repeated string database = 1;
- getDatabaseCount() - Method in interface alluxio.grpc.table.GetAllDatabasesPResponseOrBuilder
-
repeated string database = 1;
- getDatabaseList() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
repeated string database = 1;
- getDatabaseList() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
repeated string database = 1;
- getDatabaseList() - Method in interface alluxio.grpc.table.GetAllDatabasesPResponseOrBuilder
-
repeated string database = 1;
- GetDatabasePRequest - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetDatabasePRequest
- GetDatabasePRequest.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetDatabasePRequest
- GetDatabasePRequestOrBuilder - Interface in alluxio.grpc.table
-
- GetDatabasePResponse - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetDatabasePResponse
- GetDatabasePResponse.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetDatabasePResponse
- GetDatabasePResponseOrBuilder - Interface in alluxio.grpc.table
-
- getDataBindHost() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getDataBindHost() - Method in interface alluxio.worker.WorkerProcess
-
- getDataBuffer(Channel, long, int) - Method in interface alluxio.worker.netty.AbstractReadHandler.PacketReader
-
Returns the appropriate
DataBuffer
representing the data to send, depending on the
configurable transfer type.
- getDataBuffer(Channel, long, int) - Method in class alluxio.worker.netty.FileReadHandler.FilePacketReader
-
- getDataBuilder() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- getDataBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getDataBuilder() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- getDataCacheDirs() - Method in class alluxio.fuse.options.MountOptions
-
- getDataCacheSizes() - Method in class alluxio.fuse.options.MountOptions
-
- getDataCase() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- getDataCase() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
- getDataCase() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
- getDataCols(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataCols(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataCols(int) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsBuilder(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsBuilderList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsCount() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsList() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsOrBuilder(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsOrBuilder(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsOrBuilder(int) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsOrBuilderList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsOrBuilderList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataColsOrBuilderList() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- getDataCount() - Method in class alluxio.grpc.Command.Builder
-
repeated int64 data = 2;
- getDataCount() - Method in class alluxio.grpc.Command
-
repeated int64 data = 2;
- getDataCount() - Method in interface alluxio.grpc.CommandOrBuilder
-
repeated int64 data = 2;
- getDataDomainSocketPath() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getDataDomainSocketPath() - Method in interface alluxio.worker.WorkerProcess
-
- getDataFileChannel(PageId, int, int, CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
-
- getDataFileChannel(PageId, int, int, CacheContext) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- getDataFileChannel(PageId, int, int, CacheContext) - Method in class alluxio.client.file.cache.LocalCacheManager
-
- getDataFileChannel(long, int) - Method in class alluxio.client.file.cache.LocalCachePositionReader
-
- getDataFileChannel(PageId, int, int, CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- getDataFileChannel(PageId, int, int, boolean) - Method in interface alluxio.client.file.cache.PageStore
-
- getDataFileChannel(PageId, int, int, boolean) - Method in class alluxio.client.file.cache.store.LocalPageStore
-
- getDataFileChannel(PageId, int, int, boolean) - Method in class alluxio.client.file.cache.TimeBoundPageStore
-
- getDataList() - Method in class alluxio.grpc.Command.Builder
-
repeated int64 data = 2;
- getDataList() - Method in class alluxio.grpc.Command
-
repeated int64 data = 2;
- getDataList() - Method in interface alluxio.grpc.CommandOrBuilder
-
repeated int64 data = 2;
- getDataLocalPort() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getDataLocalPort() - Method in interface alluxio.worker.WorkerProcess
-
- getDataOrBuilder() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- getDataOrBuilder() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
Deprecated.
- getDataOrBuilder() - Method in interface alluxio.grpc.DownloadSnapshotPResponseOrBuilder
-
Deprecated.
- getDataOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getDataOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getDataOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getDataOrBuilder() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- getDataOrBuilder() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
Deprecated.
- getDataOrBuilder() - Method in interface alluxio.grpc.UploadSnapshotPRequestOrBuilder
-
Deprecated.
- getDataPoints() - Method in class alluxio.metrics.TimeSeries
-
- getDataPoints() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- getDataPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 dataPort = 3;
- getDataPort() - Method in class alluxio.grpc.WorkerNetAddress
-
optional int32 dataPort = 3;
- getDataPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional int32 dataPort = 3;
- getDataPort() - Method in class alluxio.wire.WorkerNetAddress
-
- getDataPortSocketAddress(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Extracts dataPort socket address from Alluxio representation of network address.
- getDate() - Method in class alluxio.s3.signature.AwsCredential
-
- getDate() - Method in class alluxio.s3.signature.SignatureInfo
-
- getDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateTime() - Method in class alluxio.s3.signature.SignatureInfo
-
- getDaysSinceEpoch() - Method in class alluxio.grpc.table.Date.Builder
-
required int64 days_since_epoch = 1;
- getDaysSinceEpoch() - Method in class alluxio.grpc.table.Date
-
required int64 days_since_epoch = 1;
- getDaysSinceEpoch() - Method in interface alluxio.grpc.table.DateOrBuilder
-
required int64 days_since_epoch = 1;
- getDb() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
optional .alluxio.grpc.table.Database db = 1;
- getDb() - Method in class alluxio.grpc.table.GetDatabasePResponse
-
optional .alluxio.grpc.table.Database db = 1;
- getDb() - Method in interface alluxio.grpc.table.GetDatabasePResponseOrBuilder
-
optional .alluxio.grpc.table.Database db = 1;
- getDb() - Method in class alluxio.rocks.RocksStore
-
- getDbBuilder() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
optional .alluxio.grpc.table.Database db = 1;
- getDBInodeColumn() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
A testing only method to access the internal objects.
- getDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string db_name = 4;
- getDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string db_name = 4;
- getDbName() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string db_name = 4;
- getDbName() - Method in class alluxio.grpc.table.Database.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.Database
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.DetachDatabasePRequestOrBuilder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.GetDatabasePRequestOrBuilder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.GetTablePRequest
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string db_name = 3;
- getDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
optional string db_name = 3;
- getDbName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
optional string db_name = 3;
- getDbName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.ReadTablePRequest
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.SyncDatabasePRequestOrBuilder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.TableInfo
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.grpc.table.TransformTablePRequest
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string db_name = 4;
- getDbNameBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string db_name = 4;
- getDbNameBytes() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string db_name = 4;
- getDbNameBytes() - Method in class alluxio.grpc.table.Database.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.Database
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.DetachDatabasePRequest
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.DetachDatabasePRequestOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.GetDatabasePRequest
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.GetDatabasePRequestOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.GetTablePRequest
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string db_name = 3;
- getDbNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
optional string db_name = 3;
- getDbNameBytes() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
optional string db_name = 3;
- getDbNameBytes() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.ReadTablePRequest
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.SyncDatabasePRequest
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.SyncDatabasePRequestOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.TableInfo
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.grpc.table.TransformTablePRequest
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
-
optional string db_name = 1;
- getDbOrBuilder() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
optional .alluxio.grpc.table.Database db = 1;
- getDbOrBuilder() - Method in class alluxio.grpc.table.GetDatabasePResponse
-
optional .alluxio.grpc.table.Database db = 1;
- getDbOrBuilder() - Method in interface alluxio.grpc.table.GetDatabasePResponseOrBuilder
-
optional .alluxio.grpc.table.Database db = 1;
- getDebug() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets debug.
- getDebug() - Method in class alluxio.wire.MasterWebUIInit
-
Gets debug.
- getDebug() - Method in class alluxio.wire.MasterWebUILogs
-
Gets debug.
- getDebug() - Method in class alluxio.wire.MasterWebUIMasters
-
Gets debug.
- getDebug() - Method in class alluxio.wire.MasterWebUIMountTable
-
Gets debug.
- getDebug() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets debug.
- getDebug() - Method in class alluxio.wire.MasterWebUIWorkers
-
Gets debug.
- getDebug() - Method in class alluxio.wire.WorkerWebUIInit
-
Gets debug.
- getDebug() - Method in class alluxio.wire.WorkerWebUILogs
-
Gets debug.
- getDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecommissionedWorkerCount() - Method in interface alluxio.master.block.BlockMaster
-
- getDecommissionedWorkerCount() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getDecommissionedWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 decommissionedWorkerNum = 8;
- getDecommissionedWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int32 decommissionedWorkerNum = 8;
- getDecommissionedWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int32 decommissionedWorkerNum = 8;
- getDecommissionWorkerMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getDefaultAcl() - Method in class alluxio.client.file.URIStatus
-
- getDefaultAcl() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- getDefaultAcl() - Method in class alluxio.grpc.FileInfo
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- getDefaultAcl() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- getDefaultAcl() - Method in class alluxio.master.file.contexts.CreateDirectoryContext
-
- getDefaultACL() - Method in class alluxio.master.file.meta.Inode
-
- getDefaultACL() - Method in interface alluxio.master.file.meta.InodeView
-
- getDefaultACL() - Method in class alluxio.master.file.meta.MutableInodeDirectory
-
- getDefaultACL() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getDefaultAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- getDefaultAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- getDefaultAcl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- getDefaultAcl() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- getDefaultAcl() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- getDefaultAcl() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- getDefaultAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- getDefaultAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- getDefaultAcl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- getDefaultAcl() - Method in class alluxio.wire.FileInfo
-
- getDefaultAclBuilder() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- getDefaultAclBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- getDefaultAclBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- getDefaultAclBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- getDefaultAclOrBuilder() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- getDefaultAclOrBuilder() - Method in class alluxio.grpc.FileInfo
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- getDefaultAclOrBuilder() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- getDefaultAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- getDefaultAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- getDefaultAclOrBuilder() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- getDefaultAclOrBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- getDefaultAclOrBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- getDefaultAclOrBuilder() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- getDefaultAclOrBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- getDefaultAclOrBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- getDefaultAclOrBuilder() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- getDefaultBlockSize() - Method in class alluxio.hadoop.AbstractFileSystem
-
- getDefaultInstance() - Static method in class alluxio.grpc.ActionInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.AddPolicyPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.AddPolicyPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.AddPolicyPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.AddQuorumServerRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.AsyncCacheRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.AsyncCacheResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.BackupPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.BackupPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.BackupPStatus
-
- getDefaultInstance() - Static method in class alluxio.grpc.BackupStatusPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.Block
-
- getDefaultInstance() - Static method in class alluxio.grpc.BlockHeartbeatPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.BlockHeartbeatPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.BlockHeartbeatPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.BlockIdList
-
- getDefaultInstance() - Static method in class alluxio.grpc.BlockInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.BlockLocation
-
- getDefaultInstance() - Static method in class alluxio.grpc.BlockMasterInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.BlockStatus
-
- getDefaultInstance() - Static method in class alluxio.grpc.BlockStoreLocationProto
-
- getDefaultInstance() - Static method in class alluxio.grpc.BuildVersion
-
- getDefaultInstance() - Static method in class alluxio.grpc.CacheRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CacheResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CancelPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CancelPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CancelPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CancelTaskCommand
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckAccessPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckAccessPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckAccessPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckConsistencyPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckConsistencyPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckConsistencyPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckpointPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckpointPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.Chunk
-
- getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ClientMetrics
-
- getDefaultInstance() - Static method in class alluxio.grpc.CmdProgress
-
- getDefaultInstance() - Static method in class alluxio.grpc.CmdStatusBlock
-
- getDefaultInstance() - Static method in class alluxio.grpc.CmdSummary
-
- getDefaultInstance() - Static method in class alluxio.grpc.Command
-
- getDefaultInstance() - Static method in class alluxio.grpc.CommitBlockPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CommitBlockPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CommitBlockPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CompleteFilePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CompleteFilePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CompleteFilePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ConfigCheckReport
-
- getDefaultInstance() - Static method in class alluxio.grpc.ConfigProperties
-
- getDefaultInstance() - Static method in class alluxio.grpc.ConfigProperty
-
- getDefaultInstance() - Static method in class alluxio.grpc.CopyJobPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CopyRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CopyResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CreateDirectoryPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CreateDirectoryPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CreateDirectoryPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CreateFilePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CreateFilePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CreateFilePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.DecommissionWorkerPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.DecommissionWorkerPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.DeletePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.DeletePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.DeletePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.DownloadSnapshotPRequest
-
Deprecated.
- getDefaultInstance() - Static method in class alluxio.grpc.DownloadSnapshotPResponse
-
Deprecated.
- getDefaultInstance() - Static method in class alluxio.grpc.ErrorInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.ExistsPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.ExistsPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ExistsPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.File
-
- getDefaultInstance() - Static method in class alluxio.grpc.FileBlockInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.FileFailure
-
- getDefaultInstance() - Static method in class alluxio.grpc.FileInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.FileSystemCommand
-
- getDefaultInstance() - Static method in class alluxio.grpc.FileSystemCommandOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.FreePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.FreePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.FreePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.FreeWorkerRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.FreeWorkerResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.FsOpPId
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetActionInfoOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetActionInfoRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetActionInfoResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetBlockInfoPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetBlockInfoPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetBlockInfoPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetCapacityBytesPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetCapacityBytesPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetConfigHashPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetConfigHashPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetConfigReportPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetConfigReportPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetConfigurationPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetConfigurationPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetFileInfoPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetFileInfoPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetFileInfoPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetFilePathPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetFilePathPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobMasterIdPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobMasterIdPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobMasterIdPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobProgressPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobProgressPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMasterIdPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMasterIdPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMasterIdPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMasterInfoPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMasterInfoPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMetricsPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMetricsPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMountIdPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMountIdPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMountTablePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMountTablePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetNodeStatePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetNodeStatePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetPolicyStatusPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetPolicyStatusPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetPolicyStatusPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetQuorumInfoPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetQuorumInfoPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetQuorumInfoPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetRegisterLeasePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetRegisterLeasePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetRegisterLeasePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetServiceVersionPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetServiceVersionPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- getDefaultInstance() - Static method in class alluxio.grpc.GetSnapshotInfoResponse
-
Deprecated.
- getDefaultInstance() - Static method in class alluxio.grpc.GetSnapshotRequest
-
Deprecated.
- getDefaultInstance() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStatusPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStatusPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStatusPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetUfsInfoPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetUfsInfoPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetUfsInfoPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetUsedBytesPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetUsedBytesPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerIdPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerIdPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerIdPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerReportPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.InconsistentProperties
-
- getDefaultInstance() - Static method in class alluxio.grpc.InconsistentProperty
-
- getDefaultInstance() - Static method in class alluxio.grpc.InconsistentPropertyValues
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobCommand
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobDescription
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobHeartbeatPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobHeartbeatPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobHeartbeatPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobMasterStatus
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobProgress
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobProgressPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobServiceSummary
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobStatusBlock
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobUnused
-
- getDefaultInstance() - Static method in class alluxio.grpc.JobWorkerHealth
-
- getDefaultInstance() - Static method in class alluxio.grpc.JournalQueryRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- getDefaultInstance() - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListAllPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListAllPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListAllPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListPolicyPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListPolicyPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListPolicyPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListProxyStatusPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListProxyStatusPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListProxyStatusPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPartialPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPartialPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPartialPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.LoadFileFailure
-
- getDefaultInstance() - Static method in class alluxio.grpc.LoadFileRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.LoadFileResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.LoadJobPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.LoadMetadataPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.LoadRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.LoadResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.LocationBlockIdListEntry
-
- getDefaultInstance() - Static method in class alluxio.grpc.MasterHeartbeatPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.MasterHeartbeatPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.MasterHeartbeatPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.MasterInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.MasterVersion
-
- getDefaultInstance() - Static method in class alluxio.grpc.MessagingRequestHeader
-
- getDefaultInstance() - Static method in class alluxio.grpc.MessagingResponseHeader
-
- getDefaultInstance() - Static method in class alluxio.grpc.Metric
-
- getDefaultInstance() - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.MetricValue
-
- getDefaultInstance() - Static method in class alluxio.grpc.MountPointInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.MountPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.MountPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.MountPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.MoveBlockRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.MoveBlockResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.MoveJobPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.MoveRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.MoveResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.NeedsSyncRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.NeedsSyncResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.NetAddress
-
- getDefaultInstance() - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.OpenFilePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.PAcl
-
- getDefaultInstance() - Static method in class alluxio.grpc.PAclEntry
-
- getDefaultInstance() - Static method in class alluxio.grpc.PersistCommandOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.PersistFile
-
- getDefaultInstance() - Static method in class alluxio.grpc.PMode
-
- getDefaultInstance() - Static method in class alluxio.grpc.PolicyInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.PolicyStatus
-
- getDefaultInstance() - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ProxyStatus
-
- getDefaultInstance() - Static method in class alluxio.grpc.QuorumServerInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.ReadRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ReadResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterCommand
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobMasterPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobMasterPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobMasterPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterMasterPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterMasterPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterMasterPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterWorkerPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterWorkerPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.RegisterWorkerPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemoveBlockRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemoveBlockResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemovePolicyPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemovePolicyPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemovePolicyPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RenamePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.RenamePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.RenamePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ResetPrioritiesPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.ResetPrioritiesPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ResetPrioritiesPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RetryInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.ReverseResolvePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ReverseResolvePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.Route
-
- getDefaultInstance() - Static method in class alluxio.grpc.RouteFailure
-
- getDefaultInstance() - Static method in class alluxio.grpc.RunPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.RunPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.RunPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.RunTaskCommand
-
- getDefaultInstance() - Static method in class alluxio.grpc.S3SyntaxOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.SaslMessage
-
- getDefaultInstance() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.SetAclPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.SetAclPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.SetAclPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.SetAttributePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.SetAttributePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.SetAttributePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.SetPathConfigurationPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.SetPathConfigurationPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.SetPathConfigurationPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
-
- getDefaultInstance() - Static method in class alluxio.grpc.SnapshotData
-
- getDefaultInstance() - Static method in class alluxio.grpc.SnapshotMetadata
-
- getDefaultInstance() - Static method in class alluxio.grpc.StatusSummary
-
- getDefaultInstance() - Static method in class alluxio.grpc.StopJobPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.StopJobPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.StorageList
-
- getDefaultInstance() - Static method in class alluxio.grpc.SubmitJobPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.SubmitJobPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.SubmitOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.SubmitRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.SubmitResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.AllOrNoneSet
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.AttachDatabasePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.AttachDatabasePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.BinaryColumnStatsData
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.BooleanColumnStatsData
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.ColumnStatisticsData
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.ColumnStatisticsList
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Constraint
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Database
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Date
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.DateColumnStatsData
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Decimal
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.DecimalColumnStatsData
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.DetachDatabasePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.DetachDatabasePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Domain
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.DoubleColumnStatsData
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.EquatableValueSet
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.FieldSchema
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.FileStatistics
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetAllTablesPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetAllTablesPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetDatabasePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetDatabasePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetTablePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetTablePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Layout
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.layout.hive.Storage
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.LayoutSpec
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.LongColumnStatsData
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Partition
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.PartitionSpec
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Range
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.RangeSet
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.ReadTablePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.ReadTablePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Schema
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.StringColumnStatsData
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.SyncDatabasePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.SyncDatabasePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.SyncStatus
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.TableInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Transformation
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.TransformJobInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.TransformTablePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.TransformTablePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.table.Value
-
- getDefaultInstance() - Static method in class alluxio.grpc.TierList
-
- getDefaultInstance() - Static method in class alluxio.grpc.TransferLeaderMessage
-
- getDefaultInstance() - Static method in class alluxio.grpc.TransferLeadershipPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.TransferLeadershipPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.TransferLeadershipPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.TransportMessage
-
- getDefaultInstance() - Static method in class alluxio.grpc.TriggerPolicyRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.TriggerPolicyResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.UfsFileStatus
-
- getDefaultInstance() - Static method in class alluxio.grpc.UfsInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.UfsReadOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.UfsStatus
-
- getDefaultInstance() - Static method in class alluxio.grpc.UnmountPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.UnmountPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.UnmountPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateConfigurationPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateConfigurationPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateMountPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateMountPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateUfsModePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateUfsModePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateUfsModePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.UploadSnapshotPRequest
-
Deprecated.
- getDefaultInstance() - Static method in class alluxio.grpc.UploadSnapshotPResponse
-
Deprecated.
- getDefaultInstance() - Static method in class alluxio.grpc.WorkerIdentity
-
- getDefaultInstance() - Static method in class alluxio.grpc.WorkerInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.WorkerLostStorageInfo
-
- getDefaultInstance() - Static method in class alluxio.grpc.WorkerNetAddress
-
- getDefaultInstance() - Static method in class alluxio.grpc.WriteOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.WriteRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.WriteRequestCommand
-
- getDefaultInstance() - Static method in class alluxio.grpc.WriteResponse
-
- getDefaultInstance() - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
- getDefaultInstance() - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.Response
-
- getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.AddMountPointEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.CompleteFileEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.DeleteFileEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.InodeFileEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.NewBlockEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.PersistFileEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.RenameEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.SetAclEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.SetAttributeEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.StringPairEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Job.CopyJobEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Job.FileFilter
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Job.LoadJobEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Job.MoveJobEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Journal.JournalEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Journal.JournalOpPId
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.meta.Block.BlockLocation
-
- getDefaultInstance() - Static method in class alluxio.proto.meta.Block.BlockMeta
-
- getDefaultInstance() - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
-
- getDefaultInstance() - Static method in class alluxio.proto.meta.InodeMeta.Inode
-
- getDefaultInstance() - Static method in class alluxio.proto.shared.Acl.AccessControlList
-
- getDefaultInstance() - Static method in class alluxio.proto.shared.Acl.AclActions
-
- getDefaultInstance() - Static method in class alluxio.proto.shared.Acl.AclEntry
-
- getDefaultInstance() - Static method in class alluxio.proto.shared.Acl.NamedAclActions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ActionInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ActionInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AddQuorumServerRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPStatus.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPStatus
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupStatusPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Block.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Block
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockIdList.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockIdList
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockLocation.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockLocation
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockMasterInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockStatus.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockStatus
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BlockStoreLocationProto
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BuildVersion.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BuildVersion
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CacheRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CacheRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CacheResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CacheResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelTaskCommand
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Chunk.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Chunk
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClientMetrics.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClientMetrics
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CmdProgress.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CmdProgress
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CmdStatusBlock
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CmdSummary.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CmdSummary
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Command.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Command
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigCheckReport
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigProperties.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigProperties
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigProperty.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigProperty
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CopyJobPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CopyRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CopyRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CopyResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CopyResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DecommissionWorkerPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPRequest
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.ErrorInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ErrorInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.File.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.File
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileBlockInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileFailure.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileFailure
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemCommand
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemCommandOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FreePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FreePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FreePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FreePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FreePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FreePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FreeWorkerRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FreeWorkerResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FsOpPId.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.FsOpPId
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCapacityBytesPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCapacityBytesPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigHashPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigHashPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigReportPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigReportPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigurationPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigurationPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetFilePathPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetFilePathPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobProgressPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobProgressPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountIdPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountIdPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountTablePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountTablePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetNodeStatePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetNodeStatePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetServiceVersionPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetServiceVersionPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotRequest
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetUsedBytesPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetUsedBytesPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentProperties.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentProperties
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentProperty
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentPropertyValues
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobCommand.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobCommand
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobDescription.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobDescription
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterStatus
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobProgress.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobProgress
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobProgressPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobServiceSummary
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobStatusBlock
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobUnused.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobUnused
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JobWorkerHealth
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileFailure
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadJobPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadMetadataPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LoadResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MasterInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MasterInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MasterVersion.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MasterVersion
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MessagingRequestHeader
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MessagingResponseHeader
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Metric.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Metric
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MetricValue.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MetricValue
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MountPointInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MountPointInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MountPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MountPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MountPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MountPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MountPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MountPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MoveBlockRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MoveBlockResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MoveBlockResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MoveJobPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MoveRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MoveRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MoveResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.MoveResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NeedsSyncRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NeedsSyncResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NetAddress.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NetAddress
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.OpenFilePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PAcl.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PAcl
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PAclEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PAclEntry
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PersistCommandOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PersistFile.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PersistFile
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PMode.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PMode
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PolicyInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PolicyInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PolicyStatus.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.PolicyStatus
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyStatus.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyStatus
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.QuorumServerInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ReadRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ReadRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ReadResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ReadResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterCommand.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterCommand
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveBlockRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveBlockResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RetryInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RetryInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ReverseResolvePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ReverseResolvePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Route.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Route
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RouteFailure.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RouteFailure
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RunPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RunPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RunPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RunPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RunPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RunPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.RunTaskCommand
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.S3SyntaxOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SaslMessage.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SaslMessage
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotData.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotData
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotMetadata
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.StatusSummary.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.StatusSummary
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.StopJobPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.StopJobPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.StopJobPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.StopJobPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.StorageList.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.StorageList
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitJobPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitJobPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.AllOrNoneSet
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.AttachDatabasePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsList
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Constraint.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Constraint
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Database.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Database
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Date.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Date
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.DateColumnStatsData
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Decimal.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Decimal
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.DetachDatabasePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.DetachDatabasePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Domain.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Domain
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.EquatableValueSet
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.FieldSchema
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.FileStatistics
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllTablesPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllTablesPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetDatabasePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetDatabasePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTablePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTablePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Layout.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Layout
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.Storage
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.LayoutSpec
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.LongColumnStatsData
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Partition.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Partition
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.PartitionSpec
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Range.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Range
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.RangeSet.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.RangeSet
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.ReadTablePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.ReadTablePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Schema.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Schema
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.StringColumnStatsData
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncDatabasePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncDatabasePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncStatus
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.TableInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.TableInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Transformation.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Transformation
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformJobInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformTablePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformTablePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Value.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.table.Value
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TierList.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TierList
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeaderMessage
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransportMessage.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransportMessage
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TriggerPolicyRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TriggerPolicyResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UfsFileStatus
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UfsInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UfsInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UfsReadOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UfsStatus.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UfsStatus
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPResponse
-
Deprecated.
- getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerIdentity.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerIdentity
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerNetAddress
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WriteOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WriteOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WriteRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WriteRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WriteRequestCommand
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WriteResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.WriteResponse
-
- getDefaultInstanceForType() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
- getDefaultInstanceForType() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Response
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.NewBlockEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.RenameEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.SetAclEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.StringPairEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.FileFilter
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Journal.JournalOpPId
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.meta.Block.BlockLocation
-
- getDefaultInstanceForType() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.meta.Block.BlockMeta
-
- getDefaultInstanceForType() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
-
- getDefaultInstanceForType() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
- getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
- getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AclActions
-
- getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AclEntry
-
- getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
- getDefaultPort() - Method in class alluxio.hadoop.AbstractFileSystem
-
- getDefaultPort() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
-
Gets the default port number on service.
- getDefaultPort() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
-
Gets the default port number on service.
- getDefaultReplication() - Method in class alluxio.hadoop.AbstractFileSystem
-
- getDefaultSupplier() - Method in class alluxio.conf.PropertyKey
-
- getDefaultValue() - Method in class alluxio.conf.PropertyKey
-
- getDefinition() - Method in class alluxio.grpc.table.Transformation.Builder
-
optional string definition = 2;
- getDefinition() - Method in class alluxio.grpc.table.Transformation
-
optional string definition = 2;
- getDefinition() - Method in interface alluxio.grpc.table.TransformationOrBuilder
-
optional string definition = 2;
- getDefinition() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string definition = 3;
- getDefinition() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string definition = 3;
- getDefinition() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string definition = 3;
- getDefinition() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string definition = 3;
- getDefinition() - Method in class alluxio.grpc.table.TransformTablePRequest
-
optional string definition = 3;
- getDefinition() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
-
optional string definition = 3;
- getDefinitionBytes() - Method in class alluxio.grpc.table.Transformation.Builder
-
optional string definition = 2;
- getDefinitionBytes() - Method in class alluxio.grpc.table.Transformation
-
optional string definition = 2;
- getDefinitionBytes() - Method in interface alluxio.grpc.table.TransformationOrBuilder
-
optional string definition = 2;
- getDefinitionBytes() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string definition = 3;
- getDefinitionBytes() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string definition = 3;
- getDefinitionBytes() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string definition = 3;
- getDefinitionBytes() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string definition = 3;
- getDefinitionBytes() - Method in class alluxio.grpc.table.TransformTablePRequest
-
optional string definition = 3;
- getDefinitionBytes() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
-
optional string definition = 3;
- getDelay() - Method in class alluxio.util.executor.ControllableQueue.DelayNode
-
- getDelegate() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getDelegate() - Method in class alluxio.master.file.meta.InodeTree
-
- getDelegate() - Method in class alluxio.master.file.meta.MountTable
-
- getDelegate() - Method in interface alluxio.master.journal.DelegatingJournaled
-
- getDelegate() - Method in class alluxio.master.meta.PathProperties
-
- getDelegate() - Method in class alluxio.underfs.MasterUfsManager
-
- getDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- getDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- getDeleteBlock() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- getDeleteBlockBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- getDeleteBlockOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- getDeleteBlockOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- getDeleteBlockOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- getDeleted() - Method in class alluxio.s3.DeleteObjectsResult
-
- getDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- getDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- getDeleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- getDeleteFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- getDeleteFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- getDeleteFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- getDeleteFileOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- getDeleteMarker() - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
-
- getDeleteMarkerVersionId() - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
-
- getDeleteMountPoint() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool deleteMountPoint = 6;
- getDeleteMountPoint() - Method in class alluxio.grpc.DeletePOptions
-
optional bool deleteMountPoint = 6;
- getDeleteMountPoint() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional bool deleteMountPoint = 6;
- getDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- getDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- getDeleteMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- getDeleteMountPointBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- getDeleteMountPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- getDeleteMountPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- getDeleteMountPointOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- getDelimiter() - Method in class alluxio.conf.PropertyKey
-
- getDelimiter() - Method in class alluxio.s3.ListBucketOptions
-
- getDelimiter() - Method in class alluxio.s3.ListBucketResult
-
- getDependencies() - Method in class alluxio.master.AbstractMaster
-
- getDependencies() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getDependencies() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getDependencies() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getDependencies() - Method in class alluxio.master.NoopMaster
-
- getDependencies() - Method in interface alluxio.Server
-
- getDependencies() - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getDependencies() - Method in class alluxio.worker.JobWorker
-
- getDeployMode() - Method in class alluxio.multi.process.MultiProcessCluster
-
- getDeprecationMessage(PropertyKey) - Static method in class alluxio.conf.PropertyKey
-
- getDepth() - Method in class alluxio.AlluxioURI
-
Returns the number of elements of the path component of the
AlluxioURI
.
- getDesc() - Method in class alluxio.cli.ValidationTaskResult
-
- getDescendants(LockedInodePath) - Method in class alluxio.master.file.meta.InodeTree
-
- getDescription() - Method in class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
-
- getDescription() - Method in class alluxio.cli.bundler.command.CollectConfigCommand
-
- getDescription() - Method in class alluxio.cli.bundler.command.CollectEnvCommand
-
- getDescription() - Method in class alluxio.cli.bundler.command.CollectJvmInfoCommand
-
- getDescription() - Method in class alluxio.cli.bundler.command.CollectLogCommand
-
- getDescription() - Method in class alluxio.cli.bundler.command.CollectMetricsCommand
-
- getDescription() - Method in interface alluxio.cli.Command
-
- getDescription() - Method in class alluxio.cli.command.metadatacache.DropAllCommand
-
- getDescription() - Method in class alluxio.cli.command.metadatacache.DropCommand
-
- getDescription() - Method in class alluxio.cli.command.metadatacache.SizeCommand
-
- getDescription() - Method in class alluxio.cli.command.MetadataCacheCommand
-
- getDescription() - Method in class alluxio.cli.extensions.command.InstallCommand
-
- getDescription() - Method in class alluxio.cli.extensions.command.LsCommand
-
- getDescription() - Method in class alluxio.cli.extensions.command.UninstallCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.CatCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.CheckCachedCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.ChecksumCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.ChgrpCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.ChmodCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.ChownCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.CpCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.FreeCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.HeadCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.HelpCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.LoadCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.LocationCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.LsCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.MkdirCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.MvCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.RmCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.StatCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.TailCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.TestCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.TouchCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.command.BackupCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.command.EnableWorkerCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.command.JournalCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.command.MetricsCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.command.NodesCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.command.ReportCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.nodes.WorkerStatusCommand
-
- getDescription() - Method in class alluxio.cli.ValidateEnv
-
Gets the task descriptions.
- getDescription() - Method in class alluxio.conf.PropertyKey
-
- getDescription() - Method in class alluxio.DefaultSupplier
-
- getDescription() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string description = 13;
- getDescription() - Method in class alluxio.grpc.JobInfo
-
optional string description = 13;
- getDescription() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string description = 13;
- getDescription() - Method in class alluxio.grpc.table.Database.Builder
-
optional string description = 2;
- getDescription() - Method in class alluxio.grpc.table.Database
-
optional string description = 2;
- getDescription() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string description = 2;
- getDescription() - Method in interface alluxio.job.wire.JobInfo
-
- getDescription() - Method in class alluxio.job.wire.PlanInfo
-
- getDescription() - Method in class alluxio.job.wire.TaskInfo
-
- getDescription() - Method in class alluxio.job.wire.WorkflowInfo
-
- getDescription() - Method in class alluxio.master.job.CopyJob
-
- getDescription() - Method in class alluxio.master.job.DoraLoadJob
-
- getDescription() - Method in class alluxio.master.job.LoadJob
-
- getDescription() - Method in class alluxio.master.job.MoveJob
-
- getDescription() - Method in class alluxio.metrics.MetricKey
-
- getDescription() - Method in class alluxio.s3.S3ErrorCode
-
- getDescription() - Method in interface alluxio.scheduler.job.Job
-
- getDescription(List<String>) - Method in class alluxio.stress.Parameters
-
Returns a string representation of the parameters, using only the specified fields.
- getDescriptionBytes() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string description = 13;
- getDescriptionBytes() - Method in class alluxio.grpc.JobInfo
-
optional string description = 13;
- getDescriptionBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string description = 13;
- getDescriptionBytes() - Method in class alluxio.grpc.table.Database.Builder
-
optional string description = 2;
- getDescriptionBytes() - Method in class alluxio.grpc.table.Database
-
optional string description = 2;
- getDescriptionBytes() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string description = 2;
- getDescriptor() - Static method in class alluxio.grpc.ActionInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ActionInfo
-
- getDescriptor() - Static method in class alluxio.grpc.AddPolicyPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.AddPolicyPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.AddPolicyPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.AddPolicyPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.AddPolicyPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.AddPolicyPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.AddQuorumServerRequest
-
- getDescriptor() - Static method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.AsyncCacheRequest
-
- getDescriptor() - Static method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.AsyncCacheResponse
-
- getDescriptor() - Static method in class alluxio.grpc.AuthenticationServerProto
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPStatus.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPStatus
-
- getDescriptor() - Static method in enum alluxio.grpc.BackupState
-
- getDescriptor() - Static method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BackupStatusPRequest
-
- getDescriptor() - Static method in enum alluxio.grpc.Bits
-
- getDescriptor() - Static method in class alluxio.grpc.Block.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.Block
-
- getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.BlockIdList.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BlockIdList
-
- getDescriptor() - Static method in class alluxio.grpc.BlockInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BlockInfo
-
- getDescriptor() - Static method in class alluxio.grpc.BlockLocation.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BlockLocation
-
- getDescriptor() - Static method in class alluxio.grpc.BlockMasterInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BlockMasterInfo
-
- getDescriptor() - Static method in enum alluxio.grpc.BlockMasterInfoField
-
- getDescriptor() - Static method in class alluxio.grpc.BlockMasterProto
-
- getDescriptor() - Static method in class alluxio.grpc.BlockStatus.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BlockStatus
-
- getDescriptor() - Static method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BlockStoreLocationProto
-
- getDescriptor() - Static method in class alluxio.grpc.BlockWorkerProto
-
- getDescriptor() - Static method in class alluxio.grpc.BuildVersion.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BuildVersion
-
- getDescriptor() - Static method in class alluxio.grpc.CacheRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CacheRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CacheResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CacheResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CancelTaskCommand.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CancelTaskCommand
-
- getDescriptor() - Static method in enum alluxio.grpc.ChannelAuthenticationScheme
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CheckpointPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckpointPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CheckpointPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckpointPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CheckRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CheckResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckResponse
-
- getDescriptor() - Static method in class alluxio.grpc.Chunk.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.Chunk
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsResponse
-
- getDescriptor() - Static method in class alluxio.grpc.ClientMetrics.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ClientMetrics
-
- getDescriptor() - Static method in class alluxio.grpc.CmdProgress.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CmdProgress
-
- getDescriptor() - Static method in class alluxio.grpc.CmdStatusBlock.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CmdStatusBlock
-
- getDescriptor() - Static method in class alluxio.grpc.CmdSummary.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CmdSummary
-
- getDescriptor() - Static method in class alluxio.grpc.Command.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.Command
-
- getDescriptor() - Static method in enum alluxio.grpc.CommandType
-
- getDescriptor() - Static method in class alluxio.grpc.CommitBlockPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CommitBlockPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CommitBlockPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CommitBlockPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CommitBlockPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CommitBlockPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CommonProto
-
- getDescriptor() - Static method in class alluxio.grpc.CompleteFilePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CompleteFilePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CompleteFilePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CompleteFilePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CompleteFilePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CompleteFilePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.ConfigCheckReport.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ConfigCheckReport
-
- getDescriptor() - Static method in class alluxio.grpc.ConfigProperties.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ConfigProperties
-
- getDescriptor() - Static method in class alluxio.grpc.ConfigProperty.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ConfigProperty
-
- getDescriptor() - Static method in enum alluxio.grpc.ConfigStatus
-
- getDescriptor() - Static method in class alluxio.grpc.CopyJobPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CopyJobPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CopyRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CopyRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CopyResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CopyResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CreateFilePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CreateFilePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CreateFilePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CreateFilePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CreateFilePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CreateFilePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.DecommissionWorkerPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.DecommissionWorkerPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.DeletePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.DeletePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.DeletePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.DeletePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.DeletePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.DeletePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPRequest
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPResponse
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.ErrorInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ErrorInfo
-
- getDescriptor() - Static method in enum alluxio.grpc.ErrorType
-
- getDescriptor() - Static method in class alluxio.grpc.ExistsPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ExistsPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.ExistsPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ExistsPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ExistsPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ExistsPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.File.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.File
-
- getDescriptor() - Static method in class alluxio.grpc.FileBlockInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FileBlockInfo
-
- getDescriptor() - Static method in class alluxio.grpc.FileFailure.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FileFailure
-
- getDescriptor() - Static method in class alluxio.grpc.FileInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FileInfo
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemCommand.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemCommand
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemCommandOptions
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.FileSystemMasterProto
-
- getDescriptor() - Static method in class alluxio.grpc.FreePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FreePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.FreePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FreePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.FreePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FreePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.FreeWorkerRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FreeWorkerRequest
-
- getDescriptor() - Static method in class alluxio.grpc.FreeWorkerResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FreeWorkerResponse
-
- getDescriptor() - Static method in class alluxio.grpc.FsCommonProto
-
- getDescriptor() - Static method in class alluxio.grpc.FsOpPId.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.FsOpPId
-
- getDescriptor() - Static method in class alluxio.grpc.GetActionInfoOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetActionInfoOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetActionInfoRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetActionInfoRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetActionInfoResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetActionInfoResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetCapacityBytesPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetCapacityBytesPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigHashPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigHashPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigHashPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigReportPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigReportPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigReportPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigurationPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetConfigurationPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetFilePathPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetFilePathPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetFilePathPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetFilePathPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobProgressPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobProgressPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMetricsPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMetricsPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetMountIdPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMountIdPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetMountIdPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMountIdPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetMountTablePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMountTablePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMountTablePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetNodeStatePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetNodeStatePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetNodeStatePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetServiceVersionPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetServiceVersionPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoResponse
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotRequest.Builder
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotRequest
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetUsedBytesPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetUsedBytesPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetUsedBytesPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetWorkerReportPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.InconsistentProperties.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.InconsistentProperties
-
- getDescriptor() - Static method in class alluxio.grpc.InconsistentProperty.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.InconsistentProperty
-
- getDescriptor() - Static method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.InconsistentPropertyValues
-
- getDescriptor() - Static method in class alluxio.grpc.JobCommand.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobCommand
-
- getDescriptor() - Static method in class alluxio.grpc.JobDescription.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobDescription
-
- getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.JobInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobInfo
-
- getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
-
- getDescriptor() - Static method in enum alluxio.grpc.JobMasterMetaCommand
-
- getDescriptor() - Static method in class alluxio.grpc.JobMasterProto
-
- getDescriptor() - Static method in class alluxio.grpc.JobMasterStatus.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobMasterStatus
-
- getDescriptor() - Static method in class alluxio.grpc.JobProgress.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobProgress
-
- getDescriptor() - Static method in class alluxio.grpc.JobProgressPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobProgressPOptions
-
- getDescriptor() - Static method in enum alluxio.grpc.JobProgressReportFormat
-
- getDescriptor() - Static method in class alluxio.grpc.JobServiceSummary.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobServiceSummary
-
- getDescriptor() - Static method in enum alluxio.grpc.JobSource
-
- getDescriptor() - Static method in class alluxio.grpc.JobStatusBlock.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobStatusBlock
-
- getDescriptor() - Static method in enum alluxio.grpc.JobType
-
- getDescriptor() - Static method in class alluxio.grpc.JobUnused.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobUnused
-
- getDescriptor() - Static method in class alluxio.grpc.JobWorkerHealth.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JobWorkerHealth
-
- getDescriptor() - Static method in enum alluxio.grpc.JournalDomain
-
- getDescriptor() - Static method in class alluxio.grpc.JournalMasterProto
-
- getDescriptor() - Static method in class alluxio.grpc.JournalQueryRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JournalQueryRequest
-
- getDescriptor() - Static method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ListAllPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListAllPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.ListAllPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListAllPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ListAllPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListAllPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.ListPolicyPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListPolicyPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.ListPolicyPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListPolicyPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ListPolicyPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListPolicyPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ListStatusPResponse
-
- getDescriptor() - Static method in enum alluxio.grpc.LoadDescendantPType
-
- getDescriptor() - Static method in class alluxio.grpc.LoadFileFailure.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.LoadFileFailure
-
- getDescriptor() - Static method in class alluxio.grpc.LoadFileRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.LoadFileRequest
-
- getDescriptor() - Static method in class alluxio.grpc.LoadFileResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.LoadFileResponse
-
- getDescriptor() - Static method in class alluxio.grpc.LoadJobPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.LoadJobPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.LoadMetadataPOptions
-
- getDescriptor() - Static method in enum alluxio.grpc.LoadMetadataPType
-
- getDescriptor() - Static method in class alluxio.grpc.LoadRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.LoadRequest
-
- getDescriptor() - Static method in class alluxio.grpc.LoadResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.LoadResponse
-
- getDescriptor() - Static method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.LocationBlockIdListEntry
-
- getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.MasterInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MasterInfo
-
- getDescriptor() - Static method in enum alluxio.grpc.MasterInfoField
-
- getDescriptor() - Static method in class alluxio.grpc.MasterVersion.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MasterVersion
-
- getDescriptor() - Static method in class alluxio.grpc.MessagingRequestHeader.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MessagingRequestHeader
-
- getDescriptor() - Static method in class alluxio.grpc.MessagingResponseHeader.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MessagingResponseHeader
-
- getDescriptor() - Static method in class alluxio.grpc.MessagingTransportProto
-
- getDescriptor() - Static method in enum alluxio.grpc.MetaCommand
-
- getDescriptor() - Static method in class alluxio.grpc.MetaMasterProto
-
- getDescriptor() - Static method in class alluxio.grpc.Metric.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.Metric
-
- getDescriptor() - Static method in class alluxio.grpc.MetricMasterProto
-
- getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
-
- getDescriptor() - Static method in enum alluxio.grpc.MetricType
-
- getDescriptor() - Static method in class alluxio.grpc.MetricValue.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MetricValue
-
- getDescriptor() - Static method in class alluxio.grpc.MountPointInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MountPointInfo
-
- getDescriptor() - Static method in class alluxio.grpc.MountPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MountPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.MountPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MountPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.MountPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MountPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.MoveBlockRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MoveBlockRequest
-
- getDescriptor() - Static method in class alluxio.grpc.MoveBlockResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MoveBlockResponse
-
- getDescriptor() - Static method in class alluxio.grpc.MoveJobPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MoveJobPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.MoveRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MoveRequest
-
- getDescriptor() - Static method in class alluxio.grpc.MoveResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.MoveResponse
-
- getDescriptor() - Static method in class alluxio.grpc.NeedsSyncRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.NeedsSyncRequest
-
- getDescriptor() - Static method in class alluxio.grpc.NeedsSyncResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.NeedsSyncResponse
-
- getDescriptor() - Static method in class alluxio.grpc.NetAddress.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.NetAddress
-
- getDescriptor() - Static method in enum alluxio.grpc.NodeState
-
- getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.OpenFilePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.OpenFilePOptions
-
- getDescriptor() - Static method in enum alluxio.grpc.OperationType
-
- getDescriptor() - Static method in class alluxio.grpc.PAcl.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.PAcl
-
- getDescriptor() - Static method in enum alluxio.grpc.PAclAction
-
- getDescriptor() - Static method in class alluxio.grpc.PAclEntry.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.PAclEntry
-
- getDescriptor() - Static method in enum alluxio.grpc.PAclEntryType
-
- getDescriptor() - Static method in class alluxio.grpc.PersistCommandOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.PersistCommandOptions
-
- getDescriptor() - Static method in class alluxio.grpc.PersistFile.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.PersistFile
-
- getDescriptor() - Static method in class alluxio.grpc.PMode.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.PMode
-
- getDescriptor() - Static method in class alluxio.grpc.PolicyInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.PolicyInfo
-
- getDescriptor() - Static method in class alluxio.grpc.PolicyMasterProto
-
- getDescriptor() - Static method in class alluxio.grpc.PolicyStatus.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.PolicyStatus
-
- getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.ProxyStatus.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ProxyStatus
-
- getDescriptor() - Static method in class alluxio.grpc.QuorumServerInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.QuorumServerInfo
-
- getDescriptor() - Static method in enum alluxio.grpc.QuorumServerState
-
- getDescriptor() - Static method in class alluxio.grpc.RaftJournalProto
-
- getDescriptor() - Static method in enum alluxio.grpc.ReadPType
-
- getDescriptor() - Static method in class alluxio.grpc.ReadRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ReadRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ReadResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ReadResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterCommand.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterCommand
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveBlockRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveBlockRequest
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveBlockResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveBlockResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RenamePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RenamePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.RenamePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RenamePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.RenamePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RenamePResponse
-
- getDescriptor() - Static method in enum alluxio.grpc.RequestType
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RetryInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RetryInfo
-
- getDescriptor() - Static method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ReverseResolvePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ReverseResolvePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.Route.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.Route
-
- getDescriptor() - Static method in class alluxio.grpc.RouteFailure.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RouteFailure
-
- getDescriptor() - Static method in class alluxio.grpc.RunPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RunPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.RunPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RunPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.RunPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RunPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RunTaskCommand.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RunTaskCommand
-
- getDescriptor() - Static method in class alluxio.grpc.S3SyntaxOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.S3SyntaxOptions
-
- getDescriptor() - Static method in class alluxio.grpc.SaslMessage.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SaslMessage
-
- getDescriptor() - Static method in enum alluxio.grpc.SaslMessageType
-
- getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
-
- getDescriptor() - Static method in enum alluxio.grpc.Scope
-
- getDescriptor() - Static method in enum alluxio.grpc.ServiceType
-
- getDescriptor() - Static method in enum alluxio.grpc.SetAclAction
-
- getDescriptor() - Static method in class alluxio.grpc.SetAclPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SetAclPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.SetAclPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SetAclPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.SetAclPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SetAclPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.SetAttributePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SetAttributePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.SetAttributePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SetAttributePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.SetAttributePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SetAttributePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
-
- getDescriptor() - Static method in class alluxio.grpc.SnapshotData.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SnapshotData
-
- getDescriptor() - Static method in class alluxio.grpc.SnapshotMetadata.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SnapshotMetadata
-
- getDescriptor() - Static method in enum alluxio.grpc.Status
-
- getDescriptor() - Static method in class alluxio.grpc.StatusSummary.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.StatusSummary
-
- getDescriptor() - Static method in class alluxio.grpc.StopJobPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.StopJobPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.StopJobPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.StopJobPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.StorageList.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.StorageList
-
- getDescriptor() - Static method in class alluxio.grpc.SubmitJobPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SubmitJobPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.SubmitJobPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SubmitJobPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.SubmitOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SubmitOptions
-
- getDescriptor() - Static method in class alluxio.grpc.SubmitRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SubmitRequest
-
- getDescriptor() - Static method in class alluxio.grpc.SubmitResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SubmitResponse
-
- getDescriptor() - Static method in enum alluxio.grpc.SyncPointStatus
-
- getDescriptor() - Static method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.AllOrNoneSet
-
- getDescriptor() - Static method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.AttachDatabasePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.AttachDatabasePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.BinaryColumnStatsData
-
- getDescriptor() - Static method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.BooleanColumnStatsData
-
- getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsData
-
- getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
-
- getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsList
-
- getDescriptor() - Static method in class alluxio.grpc.table.Constraint.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Constraint
-
- getDescriptor() - Static method in class alluxio.grpc.table.Database.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Database
-
- getDescriptor() - Static method in class alluxio.grpc.table.Date.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Date
-
- getDescriptor() - Static method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.DateColumnStatsData
-
- getDescriptor() - Static method in class alluxio.grpc.table.Decimal.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Decimal
-
- getDescriptor() - Static method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.DecimalColumnStatsData
-
- getDescriptor() - Static method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.DetachDatabasePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.DetachDatabasePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.Domain.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Domain
-
- getDescriptor() - Static method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.DoubleColumnStatsData
-
- getDescriptor() - Static method in class alluxio.grpc.table.EquatableValueSet.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.EquatableValueSet
-
- getDescriptor() - Static method in class alluxio.grpc.table.FieldSchema.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.FieldSchema
-
- getDescriptor() - Static method in class alluxio.grpc.table.FileStatistics.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.FileStatistics
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetAllTablesPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetAllTablesPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetDatabasePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetDatabasePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTablePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTablePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTablePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTablePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.Layout.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Layout
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.HiveLayoutProto
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
-
- getDescriptor() - Static method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.Storage
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
-
- getDescriptor() - Static method in class alluxio.grpc.table.LayoutSpec.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.LayoutSpec
-
- getDescriptor() - Static method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.LongColumnStatsData
-
- getDescriptor() - Static method in class alluxio.grpc.table.Partition.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Partition
-
- getDescriptor() - Static method in class alluxio.grpc.table.PartitionSpec.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.PartitionSpec
-
- getDescriptor() - Static method in enum alluxio.grpc.table.PrincipalType
-
- getDescriptor() - Static method in class alluxio.grpc.table.Range.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Range
-
- getDescriptor() - Static method in class alluxio.grpc.table.RangeSet.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.RangeSet
-
- getDescriptor() - Static method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.ReadTablePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.ReadTablePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.Schema.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Schema
-
- getDescriptor() - Static method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.StringColumnStatsData
-
- getDescriptor() - Static method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.SyncDatabasePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.SyncDatabasePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.SyncStatus.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.SyncStatus
-
- getDescriptor() - Static method in class alluxio.grpc.table.TableInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.TableInfo
-
- getDescriptor() - Static method in enum alluxio.grpc.table.TableInfo.TableType
-
- getDescriptor() - Static method in class alluxio.grpc.table.TableMasterProto
-
- getDescriptor() - Static method in class alluxio.grpc.table.Transformation.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Transformation
-
- getDescriptor() - Static method in class alluxio.grpc.table.TransformJobInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.TransformJobInfo
-
- getDescriptor() - Static method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.TransformTablePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.TransformTablePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.table.Value.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.table.Value
-
- getDescriptor() - Static method in enum alluxio.grpc.TaskStatus
-
- getDescriptor() - Static method in class alluxio.grpc.TierList.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TierList
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeaderMessage.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeaderMessage
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.TransportMessage.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TransportMessage
-
- getDescriptor() - Static method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TriggerPolicyRequest
-
- getDescriptor() - Static method in class alluxio.grpc.TriggerPolicyResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TriggerPolicyResponse
-
- getDescriptor() - Static method in enum alluxio.grpc.TtlAction
-
- getDescriptor() - Static method in class alluxio.grpc.UfsFileStatus.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UfsFileStatus
-
- getDescriptor() - Static method in class alluxio.grpc.UfsInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UfsInfo
-
- getDescriptor() - Static method in enum alluxio.grpc.UfsPMode
-
- getDescriptor() - Static method in class alluxio.grpc.UfsReadOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UfsReadOptions
-
- getDescriptor() - Static method in class alluxio.grpc.UfsStatus.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UfsStatus
-
- getDescriptor() - Static method in class alluxio.grpc.UnmountPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UnmountPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.UnmountPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UnmountPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.UnmountPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UnmountPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateMountPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateMountPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPRequest
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPResponse
-
Deprecated.
- getDescriptor() - Static method in class alluxio.grpc.VersionProto
-
- getDescriptor() - Static method in class alluxio.grpc.WorkerIdentity.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.WorkerIdentity
-
- getDescriptor() - Static method in class alluxio.grpc.WorkerInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.WorkerInfo
-
- getDescriptor() - Static method in enum alluxio.grpc.WorkerInfoField
-
- getDescriptor() - Static method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.WorkerLostStorageInfo
-
- getDescriptor() - Static method in class alluxio.grpc.WorkerNetAddress.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.WorkerNetAddress
-
- getDescriptor() - Static method in enum alluxio.grpc.WorkerRange
-
- getDescriptor() - Static method in class alluxio.grpc.WriteOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.WriteOptions
-
- getDescriptor() - Static method in enum alluxio.grpc.WritePType
-
- getDescriptor() - Static method in class alluxio.grpc.WriteRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.WriteRequest
-
- getDescriptor() - Static method in class alluxio.grpc.WriteRequestCommand.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.WriteRequestCommand
-
- getDescriptor() - Static method in class alluxio.grpc.WriteResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.WriteResponse
-
- getDescriptor() - Static method in enum alluxio.grpc.XAttrPropagationStrategy
-
- getDescriptor() - Static method in class alluxio.proto.client.Cache
-
- getDescriptor() - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
- getDescriptor() - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
- getDescriptor() - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
- getDescriptor() - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
-
- getDescriptor() - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
-
- getDescriptor() - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Response
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
- getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
- getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.Block
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.AddMountPointEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.CompleteFileEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.DeleteFileEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.InodeFileEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.NewBlockEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.PersistFileEntry
-
- getDescriptor() - Static method in enum alluxio.proto.journal.File.PSetAclAction
-
- getDescriptor() - Static method in enum alluxio.proto.journal.File.PTtlAction
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.RenameEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.RenameEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.SetAclEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.SetAttributeEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.StringPairEntry
-
- getDescriptor() - Static method in enum alluxio.proto.journal.File.UfsMode
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
- getDescriptor() - Static method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
-
- getDescriptor() - Static method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Job.CopyJobEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.Job.FileFilter.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Job.FileFilter
-
- getDescriptor() - Static method in class alluxio.proto.journal.Job
-
- getDescriptor() - Static method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Job.LoadJobEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Job.MoveJobEntry
-
- getDescriptor() - Static method in enum alluxio.proto.journal.Job.PJobState
-
- getDescriptor() - Static method in class alluxio.proto.journal.Journal
-
- getDescriptor() - Static method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Journal.JournalEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Journal.JournalOpPId
-
- getDescriptor() - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.Meta
-
- getDescriptor() - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.Policy
-
- getDescriptor() - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
- getDescriptor() - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
-
- getDescriptor() - Static method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
- getDescriptor() - Static method in class alluxio.proto.meta.Block.BlockLocation
-
- getDescriptor() - Static method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
- getDescriptor() - Static method in class alluxio.proto.meta.Block.BlockMeta
-
- getDescriptor() - Static method in class alluxio.proto.meta.Block
-
- getDescriptor() - Static method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
- getDescriptor() - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
-
- getDescriptor() - Static method in class alluxio.proto.meta.DoraMeta
-
- getDescriptor() - Static method in class alluxio.proto.meta.InodeMeta
-
- getDescriptor() - Static method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- getDescriptor() - Static method in class alluxio.proto.meta.InodeMeta.Inode
-
- getDescriptor() - Static method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
- getDescriptor() - Static method in class alluxio.proto.shared.Acl.AccessControlList
-
- getDescriptor() - Static method in enum alluxio.proto.shared.Acl.AclAction
-
- getDescriptor() - Static method in class alluxio.proto.shared.Acl.AclActions.Builder
-
- getDescriptor() - Static method in class alluxio.proto.shared.Acl.AclActions
-
- getDescriptor() - Static method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.shared.Acl.AclEntry
-
- getDescriptor() - Static method in enum alluxio.proto.shared.Acl.AclEntryType
-
- getDescriptor() - Static method in class alluxio.proto.shared.Acl
-
- getDescriptor() - Static method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
- getDescriptor() - Static method in class alluxio.proto.shared.Acl.NamedAclActions
-
- getDescriptor() - Static method in class alluxio.proto.status.Status
-
- getDescriptor() - Static method in enum alluxio.proto.status.Status.PStatus
-
- getDescriptorForType() - Method in class alluxio.grpc.ActionInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BackupPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BackupPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BackupPStatus.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.BackupState
-
- getDescriptorForType() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.Bits
-
- getDescriptorForType() - Method in class alluxio.grpc.Block.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BlockIdList.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BlockInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BlockLocation.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.BlockMasterInfoField
-
- getDescriptorForType() - Method in class alluxio.grpc.BlockStatus.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BuildVersion.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CacheRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CacheResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CancelPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CancelPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CancelPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.ChannelAuthenticationScheme
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.Chunk.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ClientMetrics.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CmdProgress.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CmdSummary.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.Command.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.CommandType
-
- getDescriptorForType() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ConfigProperties.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ConfigProperty.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.ConfigStatus
-
- getDescriptorForType() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CopyRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CopyResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.DeletePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.DeletePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.DeletePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- getDescriptorForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- getDescriptorForType() - Method in class alluxio.grpc.ErrorInfo.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.ErrorType
-
- getDescriptorForType() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ExistsPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.File.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FileFailure.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FileInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FreePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FreePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FreePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.FsOpPId.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- getDescriptorForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- getDescriptorForType() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
Deprecated.
- getDescriptorForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.InconsistentProperties.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobCommand.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobDescription.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.JobMasterMetaCommand
-
- getDescriptorForType() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobProgress.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.JobProgressReportFormat
-
- getDescriptorForType() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.JobSource
-
- getDescriptorForType() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.JobType
-
- getDescriptorForType() - Method in class alluxio.grpc.JobUnused.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.JournalDomain
-
- getDescriptorForType() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- getDescriptorForType() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListAllPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.LoadDescendantPType
-
- getDescriptorForType() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.LoadMetadataPType
-
- getDescriptorForType() - Method in class alluxio.grpc.LoadRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.LoadResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MasterInfo.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.MasterInfoField
-
- getDescriptorForType() - Method in class alluxio.grpc.MasterVersion.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.MetaCommand
-
- getDescriptorForType() - Method in class alluxio.grpc.Metric.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.MetricType
-
- getDescriptorForType() - Method in class alluxio.grpc.MetricValue.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MountPointInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MountPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MountPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MountPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MoveBlockResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MoveRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.MoveResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.NetAddress.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.NodeState
-
- getDescriptorForType() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.OperationType
-
- getDescriptorForType() - Method in class alluxio.grpc.PAcl.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.PAclAction
-
- getDescriptorForType() - Method in class alluxio.grpc.PAclEntry.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.PAclEntryType
-
- getDescriptorForType() - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.PersistFile.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.PMode.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.PolicyInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.PolicyStatus.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ProxyStatus.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.QuorumServerState
-
- getDescriptorForType() - Method in enum alluxio.grpc.ReadPType
-
- getDescriptorForType() - Method in class alluxio.grpc.ReadRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ReadResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterCommand.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RenamePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RenamePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RenamePResponse.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.RequestType
-
- getDescriptorForType() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RetryInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.Route.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RouteFailure.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RunPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RunPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RunPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SaslMessage.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.SaslMessageType
-
- getDescriptorForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.Scope
-
- getDescriptorForType() - Method in enum alluxio.grpc.ServiceType
-
- getDescriptorForType() - Method in enum alluxio.grpc.SetAclAction
-
- getDescriptorForType() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SetAclPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SetAttributePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SnapshotData.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.Status
-
- getDescriptorForType() - Method in class alluxio.grpc.StatusSummary.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.StopJobPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.StopJobPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.StorageList.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SubmitOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SubmitRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.SubmitResponse.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.SyncPointStatus
-
- getDescriptorForType() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Constraint.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Database.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Date.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Decimal.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Domain.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Layout.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Partition.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.table.PrincipalType
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Range.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.RangeSet.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Schema.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.TableInfo.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.table.TableInfo.TableType
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Transformation.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.table.Value.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.TaskStatus
-
- getDescriptorForType() - Method in class alluxio.grpc.TierList.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.TransportMessage.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.TtlAction
-
- getDescriptorForType() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UfsInfo.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.UfsPMode
-
- getDescriptorForType() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UfsStatus.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UnmountPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UnmountPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- getDescriptorForType() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- getDescriptorForType() - Method in class alluxio.grpc.WorkerIdentity.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.WorkerInfo.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.WorkerInfoField
-
- getDescriptorForType() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.WorkerRange
-
- getDescriptorForType() - Method in class alluxio.grpc.WriteOptions.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.WritePType
-
- getDescriptorForType() - Method in class alluxio.grpc.WriteRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.WriteResponse.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.XAttrPropagationStrategy
-
- getDescriptorForType() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
- getDescriptorForType() - Method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
-
- getDescriptorForType() - Method in enum alluxio.proto.dataserver.Protocol.RequestType
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
- getDescriptorForType() - Method in enum alluxio.proto.journal.File.PSetAclAction
-
- getDescriptorForType() - Method in enum alluxio.proto.journal.File.PTtlAction
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
- getDescriptorForType() - Method in enum alluxio.proto.journal.File.UfsMode
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
- getDescriptorForType() - Method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
- getDescriptorForType() - Method in enum alluxio.proto.journal.Job.PJobState
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
- getDescriptorForType() - Method in enum alluxio.proto.shared.Acl.AclAction
-
- getDescriptorForType() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
- getDescriptorForType() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
- getDescriptorForType() - Method in enum alluxio.proto.shared.Acl.AclEntryType
-
- getDescriptorForType() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
- getDescriptorForType() - Method in enum alluxio.proto.status.Status.PStatus
-
- getDesiredPattern() - Method in class alluxio.master.file.meta.LockingScheme
-
- getDestination() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
-
- getDestination() - Method in class alluxio.job.plan.migrate.MigrateCommand
-
- getDestination() - Method in class alluxio.job.plan.migrate.MigrateConfig
-
- getDetachDatabaseMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getDetailedCmdStatus(long, JobMasterClient, Set<String>, List<String>) - Static method in class alluxio.cli.util.DistributedCommandUtil
-
Get detailed information about a command.
- getDeviceSpec() - Method in class alluxio.util.UnixMountInfo
-
- getDir() - Method in class alluxio.master.backcompat.Journal
-
- getDir(int) - Method in interface alluxio.worker.block.meta.StorageTier
-
Returns a directory for the given index.
- getDirectChildrenLoaded() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool directChildrenLoaded = 13;
- getDirectChildrenLoaded() - Method in class alluxio.grpc.SetAttributePOptions
-
optional bool directChildrenLoaded = 13;
- getDirectChildrenLoaded() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional bool directChildrenLoaded = 13;
- getDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool direct_children_loaded = 12;
- getDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional bool direct_children_loaded = 12;
- getDirectChildrenLoaded() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional bool direct_children_loaded = 12;
- getDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional bool direct_children_loaded = 3;
- getDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
optional bool direct_children_loaded = 3;
- getDirectChildrenLoaded() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
-
optional bool direct_children_loaded = 3;
- getDirectMemUsed() - Static method in class alluxio.metrics.MetricsSystem
-
- getDirectoryPathsOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
-
- getDirectoryStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getDirectoryStatus(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- getDirectoryStatus(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getDirectoryStatus(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- getDirectoryStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- getDirectoryStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the directory status.
- getDirectoryStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getDirectoryStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting directory status.
- getDirIndex() - Method in interface alluxio.worker.block.meta.StorageDir
-
Returns the zero-based index of this dir in its parent
StorageTier
.
- getDirMedium() - Method in interface alluxio.worker.block.meta.StorageDir
-
- getDirPath() - Method in class alluxio.util.webui.UIStorageDir
-
Gets dir path.
- getDirPath() - Method in interface alluxio.worker.block.meta.StorageDir
-
- getDisableAreDescendantsLoadedCheck() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
Setting this to true will disable checking during metadata sync to see if the children
of a directory has been loaded.
- getDisableAreDescendantsLoadedCheck() - Method in class alluxio.grpc.ListStatusPOptions
-
Setting this to true will disable checking during metadata sync to see if the children
of a directory has been loaded.
- getDisableAreDescendantsLoadedCheck() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
Setting this to true will disable checking during metadata sync to see if the children
of a directory has been loaded.
- getDiskCapacity() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets disk capacity.
- getDiskFreeCapacity() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets disk free capacity.
- getDiskInfo() - Method in class alluxio.master.meta.JournalSpaceMonitor
-
Gets the current disk information from the system for the journal path.
- getDiskPath() - Method in class alluxio.wire.JournalDiskInfo
-
- getDiskPathWithSchema() - Method in class alluxio.wire.JournalDiskInfo
-
- getDiskUsedCapacity() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets disk used capacity.
- getDisplayMountPointInfo(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getDisplayMountPointInfo(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
-
Gets the mount point information of an Alluxio path for display purpose.
- getDisplayType() - Method in class alluxio.conf.PropertyKey
-
- getDomain() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
optional .alluxio.grpc.journal.JournalDomain domain = 1;
- getDomain() - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
optional .alluxio.grpc.journal.JournalDomain domain = 1;
- getDomain() - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
-
optional .alluxio.grpc.journal.JournalDomain domain = 1;
- getDomainSocketPath() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string domainSocketPath = 5;
- getDomainSocketPath() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string domainSocketPath = 5;
- getDomainSocketPath() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string domainSocketPath = 5;
- getDomainSocketPath() - Method in class alluxio.wire.WorkerNetAddress
-
- getDomainSocketPathBytes() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string domainSocketPath = 5;
- getDomainSocketPathBytes() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string domainSocketPath = 5;
- getDomainSocketPathBytes() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string domainSocketPath = 5;
- getDoraCacheFileSystem() - Method in class alluxio.client.file.DelegatingFileSystem
-
- getDoraCacheFileSystem() - Method in class alluxio.client.file.DoraCacheFileSystem
-
- getDoraCacheFileSystem() - Method in interface alluxio.client.file.FileSystem
-
- getDoraCacheFileSystem() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- getDoraMeta(String) - Method in interface alluxio.worker.dora.DoraMetaStore
-
queries dora metadata from the dora meta store.
- getDoraMeta(String) - Method in class alluxio.worker.dora.RocksDBDoraMetaStore
-
Queries the metadata for a file.
- getDoraWorker() - Method in class alluxio.worker.s3.S3NettyHandler
-
Get dora worker object.
- getDouble(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the double representation of the value for the given key.
- getDouble(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the double representation of the value for the given key.
- getDouble(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getDouble(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- getDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- getDoubleStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- getDoubleStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- getDoubleStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- getDoubleStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- getDoubleStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- getDoubleType() - Method in class alluxio.grpc.table.Value.Builder
-
double double_type = 2;
- getDoubleType() - Method in class alluxio.grpc.table.Value
-
double double_type = 2;
- getDoubleType() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
double double_type = 2;
- getDoubleValue() - Method in class alluxio.grpc.MetricValue.Builder
-
optional double doubleValue = 1;
- getDoubleValue() - Method in class alluxio.grpc.MetricValue
-
optional double doubleValue = 1;
- getDoubleValue() - Method in interface alluxio.grpc.MetricValueOrBuilder
-
optional double doubleValue = 1;
- getDownloadSnapshotMethod() - Static method in class alluxio.grpc.RaftJournalServiceGrpc
-
- getDst() - Method in class alluxio.grpc.Route.Builder
-
required string dst = 2;
- getDst() - Method in class alluxio.grpc.Route
-
required string dst = 2;
- getDst() - Method in interface alluxio.grpc.RouteOrBuilder
-
required string dst = 2;
- getDst() - Method in class alluxio.job.CopyJobRequest
-
- getDst() - Method in class alluxio.job.MoveJobRequest
-
- getDst() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string dst = 2;
- getDst() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required string dst = 2;
- getDst() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required string dst = 2;
- getDst() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string dst = 2;
- getDst() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required string dst = 2;
- getDst() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required string dst = 2;
- getDstBytes() - Method in class alluxio.grpc.Route.Builder
-
required string dst = 2;
- getDstBytes() - Method in class alluxio.grpc.Route
-
required string dst = 2;
- getDstBytes() - Method in interface alluxio.grpc.RouteOrBuilder
-
required string dst = 2;
- getDstBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string dst = 2;
- getDstBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required string dst = 2;
- getDstBytes() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required string dst = 2;
- getDstBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string dst = 2;
- getDstBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required string dst = 2;
- getDstBytes() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required string dst = 2;
- getDstPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string dstPath = 3;
- getDstPath() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string dstPath = 3;
- getDstPath() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string dstPath = 3;
- getDstPath() - Method in class alluxio.grpc.RenamePRequest.Builder
-
the destination path
- getDstPath() - Method in class alluxio.grpc.RenamePRequest
-
the destination path
- getDstPath() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
-
the destination path
- getDstPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
Deprecated, use new_parent_id/new_name instead
- getDstPath() - Method in class alluxio.proto.journal.File.RenameEntry
-
Deprecated, use new_parent_id/new_name instead
- getDstPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
Deprecated, use new_parent_id/new_name instead
- getDstPathBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string dstPath = 3;
- getDstPathBytes() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string dstPath = 3;
- getDstPathBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string dstPath = 3;
- getDstPathBytes() - Method in class alluxio.grpc.RenamePRequest.Builder
-
the destination path
- getDstPathBytes() - Method in class alluxio.grpc.RenamePRequest
-
the destination path
- getDstPathBytes() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
-
the destination path
- getDstPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
Deprecated, use new_parent_id/new_name instead
- getDstPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry
-
Deprecated, use new_parent_id/new_name instead
- getDstPathBytes() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
Deprecated, use new_parent_id/new_name instead
- getDuration(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the time of the key as a duration.
- getDuration(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the time of the key as a duration.
- getDuration(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getDuration() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 duration = 6;
- getDuration() - Method in class alluxio.grpc.CmdSummary
-
optional int64 duration = 6;
- getDuration() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional int64 duration = 6;
- getDuration(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getDurationInSec() - Method in class alluxio.master.job.CopyJob
-
Get duration in seconds.
- getDurationInSec() - Method in class alluxio.master.job.DoraLoadJob
-
Get duration in seconds.
- getDurationInSec() - Method in class alluxio.master.job.LoadJob
-
Get duration in seconds.
- getDurationInSec() - Method in class alluxio.master.job.MoveJob
-
Get duration in seconds.
- getDurationMs() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- getDurationMs() - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- getEC2ProductCode() - Static method in class alluxio.util.EnvironmentUtils
-
Gets the EC2 product code if any.
- getEmbeddedJournalAddresses(AlluxioConfiguration, NetworkAddressUtils.ServiceType) - Static method in class alluxio.util.ConfigurationUtils
-
Gets the embedded journal addresses to use for the given service type (either master-raft or
job-master-raft).
- getEmbeddedJournalPort() - Method in class alluxio.multi.process.MasterNetAddress
-
- getEncodedLength() - Method in interface alluxio.network.protocol.EncodedMessage
-
Returns the number bytes for the message when it is encoded.
- getEncodedLength() - Method in enum alluxio.network.protocol.RPCMessage.Type
-
- getEncodedLength() - Method in class alluxio.network.protocol.RPCProtoMessage
-
- getEncodingType() - Method in class alluxio.s3.ListBucketOptions
-
- getEncodingType() - Method in class alluxio.s3.ListBucketResult
-
- getEnd() - Method in class alluxio.wire.BlockReadRequest
-
- getEnd() - Method in class alluxio.worker.netty.ReadRequest
-
- getEndMs() - Method in class alluxio.master.predicate.interval.Interval
-
- getEndMs() - Method in class alluxio.stress.client.ClientIOTaskResult
-
- getEndMs() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- getEndMs() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- getEndTime() - Method in class alluxio.master.job.AbstractJob
-
Get end time.
- getEndTime() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional int64 end_time = 9;
- getEndTime() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional int64 end_time = 9;
- getEndTime() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional int64 end_time = 9;
- getEndTime() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional int64 end_time = 8;
- getEndTime() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional int64 end_time = 8;
- getEndTime() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional int64 end_time = 8;
- getEndTime() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional int64 end_time = 9;
- getEndTime() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional int64 end_time = 9;
- getEndTime() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional int64 end_time = 9;
- getEndTime() - Method in interface alluxio.scheduler.job.Job
-
- getEndTimeMs() - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- getEntityTag(URIStatus) - Static method in class alluxio.proxy.s3.S3RestUtils
-
This helper method is used to get the ETag xAttr on an object.
- getEntityTag(FileInfo) - Static method in class alluxio.s3.NettyRestUtils
-
This helper method is used to get the ETag xAttr on an object.
- getEntries(int) - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntries(int) - Method in class alluxio.grpc.PAcl
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntries(int) - Method in interface alluxio.grpc.PAclOrBuilder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntries(int) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- getEntries(int) - Method in class alluxio.grpc.SetAclPRequest
-
the list of ACL entries
- getEntries(int) - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the list of ACL entries
- getEntries(int) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntries(int) - Method in class alluxio.proto.journal.File.SetAclEntry
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntries(int) - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntries() - Method in class alluxio.security.authorization.AccessControlList
-
Returns a list of
AclEntry
which represent this ACL instance.
- getEntries() - Method in class alluxio.security.authorization.DefaultAccessControlList
-
Returns a list of
AclEntry
which represent this ACL instance.
- getEntries() - Method in class alluxio.security.authorization.ExtendedACLEntries
-
Returns a list of
AclEntry
which represent this ACL instance.
- getEntriesBuilder(int) - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesBuilder(int) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- getEntriesBuilder(int) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesBuilderList() - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesBuilderList() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- getEntriesBuilderList() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesCount() - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesCount() - Method in class alluxio.grpc.PAcl
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesCount() - Method in interface alluxio.grpc.PAclOrBuilder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesCount() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- getEntriesCount() - Method in class alluxio.grpc.SetAclPRequest
-
the list of ACL entries
- getEntriesCount() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the list of ACL entries
- getEntriesCount() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesCount() - Method in class alluxio.proto.journal.File.SetAclEntry
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesCount() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesList() - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesList() - Method in class alluxio.grpc.PAcl
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesList() - Method in interface alluxio.grpc.PAclOrBuilder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesList() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- getEntriesList() - Method in class alluxio.grpc.SetAclPRequest
-
the list of ACL entries
- getEntriesList() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the list of ACL entries
- getEntriesList() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesList() - Method in class alluxio.proto.journal.File.SetAclEntry
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesList() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesOrBuilder(int) - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesOrBuilder(int) - Method in class alluxio.grpc.PAcl
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesOrBuilder(int) - Method in interface alluxio.grpc.PAclOrBuilder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesOrBuilder(int) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- getEntriesOrBuilder(int) - Method in class alluxio.grpc.SetAclPRequest
-
the list of ACL entries
- getEntriesOrBuilder(int) - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the list of ACL entries
- getEntriesOrBuilder(int) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesOrBuilder(int) - Method in class alluxio.proto.journal.File.SetAclEntry
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesOrBuilder(int) - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesOrBuilderList() - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesOrBuilderList() - Method in class alluxio.grpc.PAcl
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesOrBuilderList() - Method in interface alluxio.grpc.PAclOrBuilder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- getEntriesOrBuilderList() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- getEntriesOrBuilderList() - Method in class alluxio.grpc.SetAclPRequest
-
the list of ACL entries
- getEntriesOrBuilderList() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the list of ACL entries
- getEntriesOrBuilderList() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesOrBuilderList() - Method in class alluxio.proto.journal.File.SetAclEntry
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntriesOrBuilderList() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- getEntry() - Method in interface alluxio.master.journal.JournalReader
-
Returns the next entry in the journal.
- getEntry() - Method in class alluxio.master.journal.SingleEntryJournaled
-
- getEntry() - Method in class alluxio.master.journal.ufs.UfsJournalReader
-
- getEntryCount() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional int64 entryCount = 5;
- getEntryCount() - Method in class alluxio.grpc.BackupPStatus
-
optional int64 entryCount = 5;
- getEntryCount() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional int64 entryCount = 5;
- getEntryCount() - Method in class alluxio.wire.BackupStatus
-
- getEntryCounter() - Method in class alluxio.master.backup.BackupTracker
-
- getEntryMap() - Method in class alluxio.collections.LockPool
-
- getEnum(PropertyKey, Class<T>) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the value for the given key as an enum value.
- getEnum(PropertyKey, Class<T>) - Static method in class alluxio.conf.Configuration
-
Gets the value for the given key as an enum value.
- getEnum(PropertyKey, Class<T>) - Method in class alluxio.conf.InstancedConfiguration
-
- getEnum(PropertyKey, Class<T>) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getEnumType() - Method in class alluxio.conf.PropertyKey
-
- getEof() - Method in class alluxio.grpc.SnapshotData.Builder
-
Deprecated.
- getEof() - Method in class alluxio.grpc.SnapshotData
-
Deprecated.
- getEof() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
Deprecated.
- getEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional bool eof = 5;
- getEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
optional bool eof = 5;
- getEof() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
optional bool eof = 5;
- getEquatable() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- getEquatable() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- getEquatable() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- getEquatableBuilder() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- getEquatableOrBuilder() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- getEquatableOrBuilder() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- getEquatableOrBuilder() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- getError() - Method in class alluxio.thread.AutopsyThread
-
Gets the crashing error.
- getError() - Method in class alluxio.wire.BackupStatus
-
- getError() - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- getError() - Method in class alluxio.worker.grpc.WriteRequestContext
-
- getError() - Method in class alluxio.worker.netty.ReadRequestContext
-
- getError() - Method in class alluxio.worker.netty.WriteRequestContext
-
- getErrorCode(Throwable) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Gets the corresponding error code of a throwable.
- getErrorCode() - Method in exception alluxio.s3.S3Exception
-
- getErrored() - Method in class alluxio.s3.DeleteObjectsResult
-
- getErrorMessage() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorMessage = 7;
- getErrorMessage() - Method in class alluxio.grpc.ActionInfo
-
optional string errorMessage = 7;
- getErrorMessage() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string errorMessage = 7;
- getErrorMessage() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional string errorMessage = 7;
- getErrorMessage() - Method in class alluxio.grpc.CmdSummary
-
optional string errorMessage = 7;
- getErrorMessage() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional string errorMessage = 7;
- getErrorMessage() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorMessage = 2;
- getErrorMessage() - Method in class alluxio.grpc.JobInfo
-
optional string errorMessage = 2;
- getErrorMessage() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string errorMessage = 2;
- getErrorMessage() - Method in class alluxio.job.plan.meta.PlanInfo
-
- getErrorMessage() - Method in interface alluxio.job.wire.JobInfo
-
- getErrorMessage() - Method in class alluxio.job.wire.PlanInfo
-
- getErrorMessage() - Method in class alluxio.job.wire.TaskInfo
-
- getErrorMessage() - Method in class alluxio.job.wire.WorkflowInfo
-
- getErrorMessage() - Method in class alluxio.job.workflow.WorkflowExecution
-
- getErrorMessageBytes() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorMessage = 7;
- getErrorMessageBytes() - Method in class alluxio.grpc.ActionInfo
-
optional string errorMessage = 7;
- getErrorMessageBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string errorMessage = 7;
- getErrorMessageBytes() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional string errorMessage = 7;
- getErrorMessageBytes() - Method in class alluxio.grpc.CmdSummary
-
optional string errorMessage = 7;
- getErrorMessageBytes() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional string errorMessage = 7;
- getErrorMessageBytes() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorMessage = 2;
- getErrorMessageBytes() - Method in class alluxio.grpc.JobInfo
-
optional string errorMessage = 2;
- getErrorMessageBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string errorMessage = 2;
- getErrorMsg() - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorMsg = 5;
- getErrorMsg() - Method in class alluxio.grpc.JobProgress
-
optional string errorMsg = 5;
- getErrorMsg() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional string errorMsg = 5;
- getErrorMsgBytes() - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorMsg = 5;
- getErrorMsgBytes() - Method in class alluxio.grpc.JobProgress
-
optional string errorMsg = 5;
- getErrorMsgBytes() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional string errorMsg = 5;
- getErrors() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Deprecated.
- getErrors() - Method in class alluxio.grpc.ConfigCheckReport
-
Deprecated.
- getErrors() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Deprecated.
- getErrors() - Method in class alluxio.grpc.PolicyStatus.Builder
-
Deprecated.
- getErrors() - Method in class alluxio.grpc.PolicyStatus
-
Deprecated.
- getErrors() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
Deprecated.
- getErrors() - Method in class alluxio.stress.client.ClientIOTaskResult
-
- getErrors() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- getErrors() - Method in class alluxio.stress.graph.Graph
-
- getErrors() - Method in interface alluxio.stress.TaskResult
-
- getErrors() - Method in class alluxio.stress.worker.IOTaskResult
-
- getErrors() - Method in class alluxio.stress.worker.IOTaskSummary
-
- getErrors() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- getErrorsCount() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- getErrorsCount() - Method in class alluxio.grpc.ConfigCheckReport
-
- getErrorsCount() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Scope name as key
- getErrorsCount() - Method in class alluxio.grpc.PolicyStatus.Builder
-
- getErrorsCount() - Method in class alluxio.grpc.PolicyStatus
-
- getErrorsCount() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
map<string, string> errors = 10;
- getErrorsMap() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Scope name as key
- getErrorsMap() - Method in class alluxio.grpc.ConfigCheckReport
-
Scope name as key
- getErrorsMap() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Scope name as key
- getErrorsMap() - Method in class alluxio.grpc.PolicyStatus.Builder
-
map<string, string> errors = 10;
- getErrorsMap() - Method in class alluxio.grpc.PolicyStatus
-
map<string, string> errors = 10;
- getErrorsMap() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
map<string, string> errors = 10;
- getErrorsOrDefault(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Scope name as key
- getErrorsOrDefault(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport
-
Scope name as key
- getErrorsOrDefault(String, InconsistentProperties) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Scope name as key
- getErrorsOrDefault(String, String) - Method in class alluxio.grpc.PolicyStatus.Builder
-
map<string, string> errors = 10;
- getErrorsOrDefault(String, String) - Method in class alluxio.grpc.PolicyStatus
-
map<string, string> errors = 10;
- getErrorsOrDefault(String, String) - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
map<string, string> errors = 10;
- getErrorsOrThrow(String) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Scope name as key
- getErrorsOrThrow(String) - Method in class alluxio.grpc.ConfigCheckReport
-
Scope name as key
- getErrorsOrThrow(String) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Scope name as key
- getErrorsOrThrow(String) - Method in class alluxio.grpc.PolicyStatus.Builder
-
map<string, string> errors = 10;
- getErrorsOrThrow(String) - Method in class alluxio.grpc.PolicyStatus
-
map<string, string> errors = 10;
- getErrorsOrThrow(String) - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
map<string, string> errors = 10;
- getErrorString(String, String, String) - Method in class alluxio.fuse.options.BaseValueConverter
-
Format an error string describing the reason why the conversion failed.
- getErrorType() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorType = 6;
- getErrorType() - Method in class alluxio.grpc.ActionInfo
-
optional string errorType = 6;
- getErrorType() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string errorType = 6;
- getErrorType() - Method in class alluxio.grpc.ErrorInfo.Builder
-
optional .alluxio.grpc.ErrorType errorType = 1;
- getErrorType() - Method in class alluxio.grpc.ErrorInfo
-
optional .alluxio.grpc.ErrorType errorType = 1;
- getErrorType() - Method in interface alluxio.grpc.ErrorInfoOrBuilder
-
optional .alluxio.grpc.ErrorType errorType = 1;
- getErrorType() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorType = 15;
- getErrorType() - Method in class alluxio.grpc.JobInfo
-
optional string errorType = 15;
- getErrorType() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string errorType = 15;
- getErrorType() - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorType = 6;
- getErrorType() - Method in class alluxio.grpc.JobProgress
-
optional string errorType = 6;
- getErrorType() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional string errorType = 6;
- getErrorType(Throwable) - Static method in class alluxio.job.ErrorUtils
-
- getErrorType() - Method in class alluxio.job.plan.meta.PlanInfo
-
- getErrorType() - Method in interface alluxio.job.wire.JobInfo
-
- getErrorType() - Method in class alluxio.job.wire.PlanInfo
-
- getErrorType() - Method in class alluxio.job.wire.TaskInfo
-
- getErrorType() - Method in class alluxio.job.wire.WorkflowInfo
-
- getErrorType() - Method in class alluxio.job.workflow.WorkflowExecution
-
- getErrorTypeBytes() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorType = 6;
- getErrorTypeBytes() - Method in class alluxio.grpc.ActionInfo
-
optional string errorType = 6;
- getErrorTypeBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string errorType = 6;
- getErrorTypeBytes() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorType = 15;
- getErrorTypeBytes() - Method in class alluxio.grpc.JobInfo
-
optional string errorType = 15;
- getErrorTypeBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string errorType = 15;
- getErrorTypeBytes() - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorType = 6;
- getErrorTypeBytes() - Method in class alluxio.grpc.JobProgress
-
optional string errorType = 6;
- getErrorTypeBytes() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional string errorType = 6;
- getETag() - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest.Part
-
- getETag() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- getEtag() - Method in class alluxio.proxy.s3.CopyPartResult
-
- getETag() - Method in class alluxio.proxy.s3.ListPartsResult.Part
-
- getEtag() - Method in class alluxio.s3.CopyObjectResult
-
- getEtcdClient() - Method in class alluxio.membership.AlluxioEtcdClient
-
Get the jetcd client instance.
- getEvictBatchSize() - Method in class alluxio.master.metastore.caching.CacheConfiguration
-
- getEvictor() - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
- getEvictorClass() - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
-
- getException() - Method in class alluxio.client.file.ConfigHashSync
-
- getException() - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
-
Gets the exception during execution.
- getException() - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Returns the exception thrown by the base computation, or a CancellationException
if
cancelled, or null
if none or if the method has not yet completed.
- getExcludeMountInfo() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
Mount info will be excluded from the list status response if this field is set to true.
- getExcludeMountInfo() - Method in class alluxio.grpc.ListStatusPOptions
-
Mount info will be excluded from the list status response if this field is set to true.
- getExcludeMountInfo() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
Mount info will be excluded from the list status response if this field is set to true.
- getExecution(WorkflowConfig) - Method in enum alluxio.job.workflow.WorkflowExecutionRegistry
-
- getExecutor() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getExecutorService() - Method in class alluxio.master.AbstractMaster
-
- getExecutorService() - Method in class alluxio.worker.AbstractWorker
-
- getExistingDirectoryStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getExistingDirectoryStatus(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
-
- getExistingDirectoryStatus(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- getExistingDirectoryStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- getExistingDirectoryStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the directory status.
- getExistingDirectoryStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getExistingFileStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getExistingFileStatus(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
-
- getExistingFileStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- getExistingFileStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the file status.
- getExistingFileStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getExistingInodeCount() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getExistingStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getExistingStatus(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
-
- getExistingStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- getExistingStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the file or directory status.
- getExistingStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getExists() - Method in class alluxio.grpc.ExistsPResponse.Builder
-
optional bool exists = 1;
- getExists() - Method in class alluxio.grpc.ExistsPResponse
-
optional bool exists = 1;
- getExists() - Method in interface alluxio.grpc.ExistsPResponseOrBuilder
-
optional bool exists = 1;
- getExists() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional bool exists = 3;
- getExists() - Method in class alluxio.grpc.SnapshotMetadata
-
optional bool exists = 3;
- getExists() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
-
optional bool exists = 3;
- getExistsMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getExistsMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getExitCode() - Method in class alluxio.shell.CommandReturn
-
Gets the exit code.
- getExitCode() - Method in exception alluxio.util.ShellUtils.ExitCodeException
-
Gets the exit code.
- getExpiryMs() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional int64 expiryMs = 3;
- getExpiryMs() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
optional int64 expiryMs = 3;
- getExpiryMs() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
-
optional int64 expiryMs = 3;
- getExtendedEntries() - Method in class alluxio.security.authorization.AccessControlList
-
- getFactory() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns the factory used for constructing new workers.
- getFailedCmdCount() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
-
Gets the number of failed commands.
- getFailedCount() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
-
Gets the number of failed jobs.
- getFailedFiles() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
-
Gets failed files.
- getFailedFiles() - Method in class alluxio.cli.fs.command.job.JobAttempt
-
Get failed files if there's any.
- getFailedFiles() - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Return a copy of failed paths.
- getFailedMembers() - Method in class alluxio.membership.EtcdMembershipManager
-
- getFailedMembers() - Method in class alluxio.membership.MasterMembershipManager
-
- getFailedMembers() - Method in interface alluxio.membership.MembershipManager
-
Get all failed workers.
- getFailedMembers() - Method in class alluxio.membership.StaticMembershipManager
-
- getFailedNodeInfos() - Method in class alluxio.wire.MasterWebUIWorkers
-
Get failed node infos node info [ ].
- getFailedPaths(long) - Method in class alluxio.master.job.JobMaster
-
- getFailures(int) - Method in class alluxio.grpc.CopyResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailures(int) - Method in class alluxio.grpc.CopyResponse
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailures(int) - Method in interface alluxio.grpc.CopyResponseOrBuilder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailures(int) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailures(int) - Method in class alluxio.grpc.LoadFileResponse
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailures(int) - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailures(int) - Method in class alluxio.grpc.MoveResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailures(int) - Method in class alluxio.grpc.MoveResponse
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailures(int) - Method in interface alluxio.grpc.MoveResponseOrBuilder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresBuilder(int) - Method in class alluxio.grpc.CopyResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresBuilder(int) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresBuilder(int) - Method in class alluxio.grpc.MoveResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresBuilderList() - Method in class alluxio.grpc.CopyResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresBuilderList() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresBuilderList() - Method in class alluxio.grpc.MoveResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresCount() - Method in class alluxio.grpc.CopyResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresCount() - Method in class alluxio.grpc.CopyResponse
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresCount() - Method in interface alluxio.grpc.CopyResponseOrBuilder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresCount() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresCount() - Method in class alluxio.grpc.LoadFileResponse
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresCount() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresCount() - Method in class alluxio.grpc.MoveResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresCount() - Method in class alluxio.grpc.MoveResponse
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresCount() - Method in interface alluxio.grpc.MoveResponseOrBuilder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresList() - Method in class alluxio.grpc.CopyResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresList() - Method in class alluxio.grpc.CopyResponse
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresList() - Method in interface alluxio.grpc.CopyResponseOrBuilder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresList() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresList() - Method in class alluxio.grpc.LoadFileResponse
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresList() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresList() - Method in class alluxio.grpc.MoveResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresList() - Method in class alluxio.grpc.MoveResponse
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresList() - Method in interface alluxio.grpc.MoveResponseOrBuilder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilder(int) - Method in class alluxio.grpc.CopyResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilder(int) - Method in class alluxio.grpc.CopyResponse
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilder(int) - Method in interface alluxio.grpc.CopyResponseOrBuilder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilder(int) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresOrBuilder(int) - Method in class alluxio.grpc.LoadFileResponse
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresOrBuilder(int) - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresOrBuilder(int) - Method in class alluxio.grpc.MoveResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilder(int) - Method in class alluxio.grpc.MoveResponse
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilder(int) - Method in interface alluxio.grpc.MoveResponseOrBuilder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilderList() - Method in class alluxio.grpc.CopyResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilderList() - Method in class alluxio.grpc.CopyResponse
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilderList() - Method in interface alluxio.grpc.CopyResponseOrBuilder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilderList() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresOrBuilderList() - Method in class alluxio.grpc.LoadFileResponse
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresOrBuilderList() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- getFailuresOrBuilderList() - Method in class alluxio.grpc.MoveResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilderList() - Method in class alluxio.grpc.MoveResponse
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFailuresOrBuilderList() - Method in interface alluxio.grpc.MoveResponseOrBuilder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- getFalsePositiveRatio() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- getFalsePositiveRatio() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- getFalsePositiveRatio() - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
- getFatalError() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets fatal error.
- getFatalError() - Method in class alluxio.wire.MasterWebUIData
-
Gets fatal error.
- getFatalError() - Method in class alluxio.wire.MasterWebUILogs
-
Gets fatal error.
- getFatalError() - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Gets fatal error.
- getFatalError() - Method in class alluxio.wire.WorkerWebUILogs
-
Gets fatal error.
- getFieldRange() - Method in class alluxio.client.block.options.GetWorkerReportOptions
-
- getFieldRanges(int) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- getFieldRanges(int) - Method in class alluxio.grpc.GetWorkerReportPOptions
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- getFieldRanges(int) - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- getFieldRangesCount() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- getFieldRangesCount() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- getFieldRangesCount() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- getFieldRangesList() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- getFieldRangesList() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- getFieldRangesList() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- getFieldValue(T) - Method in class alluxio.collections.IndexDefinition
-
Gets the value of the field that serves as index.
- getFile() - Method in class alluxio.grpc.FileFailure.Builder
-
required .alluxio.grpc.block.File file = 1;
- getFile() - Method in class alluxio.grpc.FileFailure
-
required .alluxio.grpc.block.File file = 1;
- getFile() - Method in interface alluxio.grpc.FileFailureOrBuilder
-
required .alluxio.grpc.block.File file = 1;
- getFileBlockInfo(long) - Method in class alluxio.wire.FileInfo
-
- getFileBlockInfoList(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getFileBlockInfoList(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
-
- getFileBlockInfoList(AlluxioURI) - Method in class alluxio.master.file.meta.FileSystemMasterView
-
- getFileBlockInfos() - Method in class alluxio.client.file.URIStatus
-
- getFileBlockInfos(int) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfos(int) - Method in class alluxio.grpc.FileInfo
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfos(int) - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfos() - Method in class alluxio.wire.FileInfo
-
- getFileBlockInfosBuilder(int) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosBuilderList() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosCount() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosCount() - Method in class alluxio.grpc.FileInfo
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosCount() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosList() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosList() - Method in class alluxio.grpc.FileInfo
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosList() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosOrBuilder(int) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosOrBuilder(int) - Method in class alluxio.grpc.FileInfo
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosOrBuilder(int) - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosOrBuilderList() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosOrBuilderList() - Method in class alluxio.grpc.FileInfo
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockInfosOrBuilderList() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- getFileBlockLocations(FileStatus, long, long) - Method in class alluxio.hadoop.AbstractFileSystem
-
- getFileBlocks() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets file blocks.
- getFileBlocksOnTier() - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Gets file blocks on tier.
- getFileBucket(int, String) - Static method in interface alluxio.client.file.cache.store.PageStoreDir
-
- getFileBuckets() - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- getFileBuilder() - Method in class alluxio.grpc.FileFailure.Builder
-
required .alluxio.grpc.block.File file = 1;
- getFileCount() - Method in class alluxio.client.file.ListStatusPartialResult
-
- getFileCount() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 fileCount = 2;
- getFileCount() - Method in class alluxio.grpc.JobProgress
-
optional int64 fileCount = 2;
- getFileCount() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional int64 fileCount = 2;
- getFileCount() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
The total number of files in the listing directory,
(i.e.
- getFileCount() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
The total number of files in the listing directory,
(i.e.
- getFileCount() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
-
The total number of files in the listing directory,
(i.e.
- getFileCount() - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Get file count.
- getFileData() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets file data.
- getFileData() - Method in class alluxio.wire.MasterWebUILogs
-
Gets file data.
- getFileData() - Method in class alluxio.wire.WorkerWebUILogs
-
Gets file data.
- getFileDatePattern() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string file_date_pattern = 6;
- getFileDatePattern() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string file_date_pattern = 6;
- getFileDatePattern() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string file_date_pattern = 6;
- getFileDatePatternBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string file_date_pattern = 6;
- getFileDatePatternBytes() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string file_date_pattern = 6;
- getFileDatePatternBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string file_date_pattern = 6;
- getFileDoesNotExistException() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets file does not exist exception.
- getFileId() - Method in class alluxio.client.file.cache.PageId
-
- getFileId() - Method in class alluxio.client.file.URIStatus
-
- getFileId() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 fileId = 1;
- getFileId() - Method in class alluxio.grpc.FileInfo
-
optional int64 fileId = 1;
- getFileId() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 fileId = 1;
- getFileId() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
the id of the file
- getFileId() - Method in class alluxio.grpc.GetFileInfoPRequest
-
the id of the file
- getFileId() - Method in interface alluxio.grpc.GetFileInfoPRequestOrBuilder
-
the id of the file
- getFileId() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
optional int64 fileId = 1;
- getFileId() - Method in class alluxio.grpc.GetFilePathPRequest
-
optional int64 fileId = 1;
- getFileId() - Method in interface alluxio.grpc.GetFilePathPRequestOrBuilder
-
optional int64 fileId = 1;
- getFileId() - Method in class alluxio.grpc.PersistFile.Builder
-
optional int64 fileId = 1;
- getFileId() - Method in class alluxio.grpc.PersistFile
-
optional int64 fileId = 1;
- getFileId() - Method in interface alluxio.grpc.PersistFileOrBuilder
-
optional int64 fileId = 1;
- getFileId(long) - Static method in class alluxio.master.block.BlockId
-
- getFileId(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getFileId(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
-
Returns the file id for a given path.
- getFileId(AlluxioURI) - Method in class alluxio.master.file.meta.FileSystemMasterView
-
Returns the file id for a given path.
- getFileId() - Method in class alluxio.master.file.PersistJob
-
- getFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
optional int64 file_id = 1;
- getFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
-
optional int64 file_id = 1;
- getFileId() - Method in interface alluxio.proto.journal.File.AsyncPersistRequestEntryOrBuilder
-
optional int64 file_id = 1;
- getFileId() - Method in class alluxio.wire.FileInfo
-
- getFileId() - Method in class alluxio.wire.PersistFile
-
- getFileInfo() - Method in class alluxio.client.file.URIStatus
-
This is an experimental API.
- getFileInfo() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo() - Method in class alluxio.grpc.CreateFilePResponse
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in interface alluxio.grpc.FileSystemMasterJobServiceGrpc.AsyncService
-
Returns the file information for a file or directory identified by the given file id.
- getFileInfo(GetFileInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceBlockingStub
-
Returns the file information for a file or directory identified by the given file id.
- getFileInfo(GetFileInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceFutureStub
-
Returns the file information for a file or directory identified by the given file id.
- getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceStub
-
Returns the file information for a file or directory identified by the given file id.
- getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in interface alluxio.grpc.FileSystemMasterWorkerServiceGrpc.AsyncService
-
Returns the file information for a file or directory identified by the given file id.
- getFileInfo(GetFileInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub
-
Returns the file information for a file or directory identified by the given file id.
- getFileInfo(GetFileInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub
-
Returns the file information for a file or directory identified by the given file id.
- getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub
-
Returns the file information for a file or directory identified by the given file id.
- getFileInfo() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo() - Method in class alluxio.grpc.GetFileInfoPResponse
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo() - Method in interface alluxio.grpc.GetFileInfoPResponseOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo() - Method in class alluxio.grpc.GetStatusPResponse
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo() - Method in interface alluxio.grpc.GetStatusPResponseOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getFileInfo(AlluxioURI, GetStatusContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getFileInfo(long) - Method in interface alluxio.master.file.FileSystemMaster
-
Returns the
FileInfo
for a given file id.
- getFileInfo(AlluxioURI, GetStatusContext) - Method in interface alluxio.master.file.FileSystemMaster
-
- getFileInfo(long) - Method in class alluxio.master.file.FileSystemMasterClient
-
- getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in class alluxio.master.file.FileSystemMasterJobServiceHandler
-
- getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
-
- getFileInfo(long) - Method in class alluxio.master.file.meta.FileSystemMasterView
-
- getFileInfo() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo() - Method in interface alluxio.proto.meta.DoraMeta.FileStatusOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfo(long) - Method in interface alluxio.worker.block.BlockWorker
-
Gets the file information.
- getFileInfo(String, GetStatusPOptions) - Method in interface alluxio.worker.dora.DoraWorker
-
Gets the file information.
- getFileInfo(String, GetStatusPOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getFileInfo(long) - Method in class alluxio.worker.file.FileSystemMasterClient
-
- getFileInfoBuilder() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoBuilder() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoBuilder() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoBuilder() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in class alluxio.grpc.CreateFilePResponse
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in class alluxio.grpc.GetFileInfoPResponse
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in interface alluxio.grpc.GetFileInfoPResponseOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in class alluxio.grpc.GetStatusPResponse
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in interface alluxio.grpc.GetStatusPResponseOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- getFileInfoOrBuilder() - Method in interface alluxio.proto.meta.DoraMeta.FileStatusOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- GetFileInfoPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetFileInfoPOptions
- GetFileInfoPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetFileInfoPOptions
- GetFileInfoPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetFileInfoPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetFileInfoPRequest
- GetFileInfoPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetFileInfoPRequest
- GetFileInfoPRequestOrBuilder - Interface in alluxio.grpc
-
- GetFileInfoPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetFileInfoPResponse
- GetFileInfoPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetFileInfoPResponse
- GetFileInfoPResponseOrBuilder - Interface in alluxio.grpc
-
- getFileInfos(int) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfos(int) - Method in class alluxio.grpc.ListStatusPartialPResponse
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfos(int) - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfos(int) - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfos(int) - Method in class alluxio.grpc.ListStatusPResponse
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfos(int) - Method in interface alluxio.grpc.ListStatusPResponseOrBuilder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfos() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets file infos.
- getFileInfos() - Method in class alluxio.wire.MasterWebUIData
-
Gets file infos.
- getFileInfos() - Method in class alluxio.wire.MasterWebUILogs
-
Gets file infos.
- getFileInfos() - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Gets file infos.
- getFileInfos() - Method in class alluxio.wire.WorkerWebUILogs
-
Gets file infos.
- getFileInfosBuilder(int) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosBuilder(int) - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosBuilderList() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosBuilderList() - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosCount() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosCount() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosCount() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosCount() - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosCount() - Method in class alluxio.grpc.ListStatusPResponse
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosCount() - Method in interface alluxio.grpc.ListStatusPResponseOrBuilder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosList() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosList() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosList() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosList() - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosList() - Method in class alluxio.grpc.ListStatusPResponse
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosList() - Method in interface alluxio.grpc.ListStatusPResponseOrBuilder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilder(int) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilder(int) - Method in class alluxio.grpc.ListStatusPartialPResponse
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilder(int) - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilder(int) - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilder(int) - Method in class alluxio.grpc.ListStatusPResponse
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilder(int) - Method in interface alluxio.grpc.ListStatusPResponseOrBuilder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilderList() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilderList() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilderList() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilderList() - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilderList() - Method in class alluxio.grpc.ListStatusPResponse
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileInfosOrBuilderList() - Method in interface alluxio.grpc.ListStatusPResponseOrBuilder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- getFileLength() - Method in class alluxio.fuse.file.FileStatus
-
- getFileLocations(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getFileLocations(String, FileLocationOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getFileLocations(String) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
-
- getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
-
- getFileLocations(String) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
-
- getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
-
- getFileLocations(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- getFileLocations(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getFileLocations(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- getFileLocations(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- getFileLocations(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the list of locations of the indicated path.
- getFileLocations(String, FileLocationOptions) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the list of locations of the indicated path given options.
- getFileLocations(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getFileLocations(String) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
-
- getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
-
- getFileLocations() - Method in class alluxio.util.webui.UIFileInfo
-
Gets file locations.
- getFileName() - Method in class alluxio.cli.fs.command.FileLocation
-
Get the file name.
- getFileOrBuilder() - Method in class alluxio.grpc.FileFailure.Builder
-
required .alluxio.grpc.block.File file = 1;
- getFileOrBuilder() - Method in class alluxio.grpc.FileFailure
-
required .alluxio.grpc.block.File file = 1;
- getFileOrBuilder() - Method in interface alluxio.grpc.FileFailureOrBuilder
-
required .alluxio.grpc.block.File file = 1;
- getFilePath(String, AlluxioConfiguration) - Static method in class alluxio.cli.fs.FileSystemShellUtils
-
Removes
Constants.HEADER
and hostname:port information
from a path, leaving only the local file path.
- getFilePath(long) - Method in interface alluxio.client.file.FileSystemMasterClient
-
- getFilePath(long) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- getFilePath() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string filePath = 4;
- getFilePath() - Method in class alluxio.grpc.ActionInfo
-
optional string filePath = 4;
- getFilePath() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string filePath = 4;
- getFilePath(GetFilePathPRequest, StreamObserver<GetFilePathPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Returns the file path of a file id
- getFilePath(GetFilePathPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Returns the file path of a file id
- getFilePath(GetFilePathPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Returns the file path of a file id
- getFilePath(GetFilePathPRequest, StreamObserver<GetFilePathPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Returns the file path of a file id
- getFilePath() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string filePath = 3;
- getFilePath() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional string filePath = 3;
- getFilePath() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional string filePath = 3;
- getFilePath() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePath = 3;
- getFilePath() - Method in class alluxio.grpc.JobStatusBlock
-
optional string filePath = 3;
- getFilePath() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
-
optional string filePath = 3;
- getFilePath() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
-
- getFilePath() - Method in class alluxio.job.plan.persist.PersistConfig
-
- getFilePath() - Method in class alluxio.job.wire.SimpleJobStatusBlock
-
Get file path of the job.
- getFilePath(GetFilePathPRequest, StreamObserver<GetFilePathPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- getFilePath() - Method in class alluxio.master.job.common.CmdInfo
-
Get file path.
- getFilePath() - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Set file path.
- getFilePathBytes() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string filePath = 4;
- getFilePathBytes() - Method in class alluxio.grpc.ActionInfo
-
optional string filePath = 4;
- getFilePathBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string filePath = 4;
- getFilePathBytes() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string filePath = 3;
- getFilePathBytes() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional string filePath = 3;
- getFilePathBytes() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional string filePath = 3;
- getFilePathBytes() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePath = 3;
- getFilePathBytes() - Method in class alluxio.grpc.JobStatusBlock
-
optional string filePath = 3;
- getFilePathBytes() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
-
optional string filePath = 3;
- getFilePathFailed() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePathFailed = 4;
- getFilePathFailed() - Method in class alluxio.grpc.JobStatusBlock
-
optional string filePathFailed = 4;
- getFilePathFailed() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
-
optional string filePathFailed = 4;
- getFilePathFailedBytes() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePathFailed = 4;
- getFilePathFailedBytes() - Method in class alluxio.grpc.JobStatusBlock
-
optional string filePathFailed = 4;
- getFilePathFailedBytes() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
-
optional string filePathFailed = 4;
- GetFilePathPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetFilePathPRequest
- GetFilePathPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetFilePathPRequest
- GetFilePathPRequestOrBuilder - Interface in alluxio.grpc
-
- GetFilePathPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetFilePathPResponse
- GetFilePathPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetFilePathPResponse
- GetFilePathPResponseOrBuilder - Interface in alluxio.grpc
-
- getFileRegion() - Method in class alluxio.worker.http.HttpResponseContext
-
Get the file region to read from the worker side.
- getFiles(String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
-
Gets the files (on the local filesystem) that match the given input path.
- getFileSize() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 fileSize = 3;
- getFileSize() - Method in class alluxio.grpc.JobProgress
-
optional int64 fileSize = 3;
- getFileSize() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional int64 fileSize = 3;
- getFileSize(String, FileSystem, RetryPolicy) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
-
get file size for a given filePath, return 0 if exceeding retries.
- getFileSize() - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Get file size.
- getFileSizeHistogram() - Method in class alluxio.master.file.meta.InodeTree
-
- getFileSizeHistogram() - Method in class alluxio.master.file.meta.InodeTreePersistentState
-
- getFileSizeTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting file size.
- getFilesPathFailed() - Method in class alluxio.job.wire.SimpleJobStatusBlock
-
Get failed file path of the job.
- getFilesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
optional int32 files_skipped = 3;
- getFilesSkipped() - Method in class alluxio.grpc.LoadFileResponse
-
optional int32 files_skipped = 3;
- getFilesSkipped() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
optional int32 files_skipped = 3;
- getFileStatus(String, GetStatusOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getFileStatus() - Method in class alluxio.fuse.file.FuseFileInOrOutStream
-
- getFileStatus() - Method in class alluxio.fuse.file.FuseFileInStream
-
- getFileStatus() - Method in class alluxio.fuse.file.FuseFileOutStream
-
- getFileStatus() - Method in interface alluxio.fuse.file.FuseFileStream
-
- getFileStatus() - Method in class alluxio.fuse.file.FusePositionReader
-
- getFileStatus() - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
-
- getFileStatus(Path) - Method in class alluxio.hadoop.AbstractFileSystem
-
If the file does not exist in Alluxio, query it from HDFS.
- getFileStatus(Path) - Method in class alluxio.hadoop.LocalCacheFileSystem
-
- getFileStatus(String, GetStatusOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
Gets stat information on a file.
- getFileStatus(String, GetStatusOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getFileStatus(String, GetStatusOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- getFileStatus(String, GetStatusOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- getFileStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the file status.
- getFileStatus(String, GetStatusOptions) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the file status.
- getFileStatus(String, GetStatusOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getFileStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting file status.
- getFilesToLoad() - Method in class alluxio.master.job.DoraLoadJob.DoraLoadTask
-
Get files to load of this task.
- getFilesToPersist() - Method in class alluxio.wire.PersistCommandOptions
-
- getFileStream() - Method in class alluxio.fuse.file.FuseFileEntry
-
Gets the fuse file stream for this entry.
- getFileSystem() - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
Get the file system on which FuseFileSystem is based.
- getFileSystem() - Method in class alluxio.job.JobServerContext
-
- getFileSystemClient() - Method in class alluxio.multi.process.Clients
-
- getFileSystemClient() - Method in class alluxio.multi.process.MultiProcessCluster
-
- getFilesystemContext() - Method in class alluxio.multi.process.MultiProcessCluster
-
- getFileSystemForUser(String) - Method in class alluxio.worker.s3.S3NettyHandler
-
- getFileSystemHeartbeatMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
-
- getFileSystemMasterClient() - Method in class alluxio.multi.process.Clients
-
- getFileSystemMasterView() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getFileSystemMasterView() - Method in interface alluxio.master.file.FileSystemMaster
-
- getFileSystemName() - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- getFileSystemName() - Method in class alluxio.fuse.StackFS
-
- getFileSystemName() - Method in interface alluxio.jnifuse.FuseFileSystem
-
- getFileSystemOptions() - Method in class alluxio.fuse.options.FuseOptions.Builder
-
- getFileSystemOptions() - Method in class alluxio.fuse.options.FuseOptions
-
- getFileTransferType() - Method in class alluxio.worker.s3.S3NettyHandler
-
Get the FileTransferType of the netty server.
- getFilter() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string filter = 5;
- getFilter() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string filter = 5;
- getFilter() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string filter = 5;
- getFilter(int) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- getFilter(int) - Method in class alluxio.grpc.GetMasterInfoPOptions
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- getFilter(int) - Method in interface alluxio.grpc.GetMasterInfoPOptionsOrBuilder
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- getFilter() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilter() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilter() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilter() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilter() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilter() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilterBuilder() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilterBuilder() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilterBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string filter = 5;
- getFilterBytes() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string filter = 5;
- getFilterBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string filter = 5;
- getFilterCount() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- getFilterCount() - Method in class alluxio.grpc.GetMasterInfoPOptions
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- getFilterCount() - Method in interface alluxio.grpc.GetMasterInfoPOptionsOrBuilder
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- getFilterList() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- getFilterList() - Method in class alluxio.grpc.GetMasterInfoPOptions
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- getFilterList() - Method in interface alluxio.grpc.GetMasterInfoPOptionsOrBuilder
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- getFilterMetricName() - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
-
- getFilterMetricName() - Method in interface alluxio.metrics.MultiValueMetricsAggregator
-
- getFilterName() - Method in class alluxio.master.predicate.DatePredicate.Factory
-
- getFilterName() - Method in class alluxio.master.predicate.DatePredicate.LastModifiedDateFactory
-
- getFilterName() - Method in class alluxio.master.predicate.TimePredicate.DateFromFileNameOlderThanFactory
-
- getFilterName() - Method in class alluxio.master.predicate.TimePredicate.Factory
-
- getFilterName() - Method in class alluxio.master.predicate.TimePredicate.UnmodifiedForFactory
-
- getFilterOrBuilder() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilterOrBuilder() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilterOrBuilder() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilterOrBuilder() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilterOrBuilder() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilterOrBuilder() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- getFilters(int) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- getFilters(int) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- getFilters(int) - Method in interface alluxio.grpc.GetBlockMasterInfoPOptionsOrBuilder
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- getFilters() - Method in interface alluxio.metrics.MetricsAggregator
-
- getFiltersCount() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- getFiltersCount() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- getFiltersCount() - Method in interface alluxio.grpc.GetBlockMasterInfoPOptionsOrBuilder
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- getFiltersList() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- getFiltersList() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- getFiltersList() - Method in interface alluxio.grpc.GetBlockMasterInfoPOptionsOrBuilder
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- getFingerprint(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getFingerprint(String) - Method in class alluxio.underfs.BaseUnderFileSystem
-
- getFingerprint(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Deprecated.
- getFingerprint(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getFirst(V) - Method in interface alluxio.collections.FieldIndex
-
Gets an object from the set of objects with the specified field value.
- getFirst(V) - Method in class alluxio.collections.NonUniqueFieldIndex
-
- getFirst() - Method in class alluxio.collections.Pair
-
- getFirst(V) - Method in class alluxio.collections.UniqueFieldIndex
-
- getFirstByField(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
-
Gets the object from the set of objects with the specified field value.
- getFirstLevelDirectory(String) - Static method in class alluxio.util.io.PathUtils
-
Gets the first level directory of the path.
- getFlush() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional bool flush = 5;
- getFlush() - Method in class alluxio.grpc.WriteRequestCommand
-
optional bool flush = 5;
- getFlush() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional bool flush = 5;
- getFolder() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool folder = 9;
- getFolder() - Method in class alluxio.grpc.FileInfo
-
optional bool folder = 9;
- getFolder() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool folder = 9;
- getFolderSuffix() - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- getFolderSuffix() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- getFolderSuffix() - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- getFolderSuffix() - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Get suffix used to encode a directory.
- getFolderSuffix() - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- getFolderSuffix() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- getFolderSuffix() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getForced() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional bool forced = 2;
- getForced() - Method in class alluxio.grpc.FreePOptions
-
optional bool forced = 2;
- getForced() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
-
optional bool forced = 2;
- getForkJoinTaskTag() - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Returns the tag for this task.
- getFormat() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
- getFormat() - Method in class alluxio.grpc.GetJobProgressPResponse
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
- getFormat() - Method in interface alluxio.grpc.GetJobProgressPResponseOrBuilder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
- getFormat() - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
- getFormat() - Method in class alluxio.grpc.JobProgressPOptions
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
- getFormat() - Method in interface alluxio.grpc.JobProgressPOptionsOrBuilder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
- getFormattedOutput() - Method in class alluxio.shell.CommandReturn
-
Formats the object to more readable format.
- getForPath(String) - Method in class alluxio.membership.AlluxioEtcdClient
-
Get latest value attached to the path.
- getFqdnHost(InetSocketAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Gets FQDN(Full Qualified Domain Name) from Java representations of network address, except
String representation which should be handled by
NetworkAddressUtils.resolveHostName(String)
which will
handle the situation where hostname is null.
- getFqdnHost(WorkerNetAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Gets FQDN(Full Qualified Domain Name) from Alluxio representation of network address.
- getFreeBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 freeBytes = 3;
- getFreeBytes() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int64 freeBytes = 3;
- getFreeBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int64 freeBytes = 3;
- getFreeBytes() - Method in class alluxio.wire.BlockMasterInfo
-
- getFreeBytesOnTiers() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- getFreeBytesOnTiers() - Method in class alluxio.worker.block.BlockWorkerMetrics
-
- getFreeCapacity() - Method in class alluxio.util.webui.StorageTierInfo
-
Gets free capacity.
- getFreeCapacity() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets free capacity.
- getFreeCapacityBytes() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get free capacity in bytes.
- getFreeMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getFreeSpacePercent() - Method in class alluxio.util.webui.NodeInfo
-
Gets free space percent.
- getFreeSpacePercent() - Method in class alluxio.util.webui.StorageTierInfo
-
Gets free space percent.
- getFreeWorkerMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getFromMetaStore(String) - Method in class alluxio.worker.dora.DoraMetaManager
-
Gets file meta from the metastore.
- getFromUfs(String) - Method in class alluxio.worker.dora.DoraMetaManager
-
Gets file meta from UFS.
- getFs() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getFsClient() - Method in class alluxio.cli.fsadmin.command.Context
-
- getFsClient() - Method in class alluxio.worker.s3.S3NettyHandler
-
Get system user FileSystem object.
- getFsContext() - Method in class alluxio.job.JobServerContext
-
- getFsPath(String, URIStatus) - Method in class alluxio.hadoop.AbstractFileSystem
-
Used to get FS native path from Alluxio file status.
- getFsPath(String, URIStatus) - Method in class alluxio.hadoop.FileSystem
-
- getFsScheme(URI) - Method in class alluxio.hadoop.AbstractFileSystem
-
Used to get FS scheme.
- getFsScheme(URI) - Method in class alluxio.hadoop.FileSystem
-
- getFsType() - Method in class alluxio.util.UnixMountInfo
-
- getFullMetricName() - Method in class alluxio.metrics.Metric
-
- getFullPath(String, String) - Static method in class alluxio.s3.NettyRestUtils
-
Gets the full path combined by bucket name and object name.
- getFuseMethodNames() - Static method in class alluxio.fuse.FuseConstants
-
- getFuseMountOptions() - Method in class alluxio.fuse.options.FuseOptions.Builder
-
- getFuseMountOptions() - Method in class alluxio.fuse.options.FuseOptions
-
- getFuseStreamFactory() - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- getFuseVersion() - Method in class alluxio.fuse.options.MountOptions
-
- getFuture() - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient.NoDataReadStreamObserver
-
- getGainPrimacyTime() - Method in class alluxio.wire.MasterInfo
-
- getGcExecutor() - Method in class alluxio.resource.DynamicResourcePool.Options
-
- getGcIntervalMs() - Method in class alluxio.resource.DynamicResourcePool.Options
-
- getGetActionInfoMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
-
- getGetAllDatabasesMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getGetAllMasterStatusMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getGetAllTablesMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getGetAllWorkerHealthMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getGetBackupStatusMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
-
- getGetBlockInfoMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getGetBlockMasterInfoMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getGetCapacityBytesMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getGetCmdStatusDetailedMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getGetCmdStatusMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getGetConfigHashMethod() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
-
- getGetConfigReportMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
-
- getGetConfigurationMethod() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
-
- getGetDatabaseMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getGetFileInfoMethod() - Static method in class alluxio.grpc.FileSystemMasterJobServiceGrpc
-
- getGetFileInfoMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
-
- getGetFilePathMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getGetJobProgressMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getGetJobServiceSummaryMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getGetJobStatusDetailedMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getGetJobStatusMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getGetLostWorkerListMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getGetMasterIdMethod() - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
-
- getGetMasterIdMethod() - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
-
- getGetMasterInfoMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
-
- getGetMetricsMethod() - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
-
- getGetMountIdMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getGetMountIdMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
-
- getGetMountTableMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getGetNewBlockIdForFileMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getGetNodeStateMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
-
- getGetPartitionColumnStatisticsMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getGetPinnedFileIdsMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
-
- getGetPolicyStatusMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
-
- getGetQuorumInfoMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
-
- getGetServiceVersionMethod() - Static method in class alluxio.grpc.ServiceVersionClientServiceGrpc
-
- getGetStateLockHoldersMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getGetStatusMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getGetStatusMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getGetTableColumnStatisticsMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getGetTableMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getGetTransferLeaderMessageMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
-
- getGetTransformJobInfoMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getGetUfsInfoMethod() - Static method in class alluxio.grpc.FileSystemMasterJobServiceGrpc
-
- getGetUfsInfoMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
-
- getGetUsedBytesMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getGetWorkerIdMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
-
- getGetWorkerInfoListMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getGetWorkerLostStorageMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getGetWorkerReportMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getGid() - Method in interface alluxio.fuse.auth.AuthPolicy
-
- getGid(String) - Method in interface alluxio.fuse.auth.AuthPolicy
-
Gets the gid based on the auth policy and file group.
- getGid() - Method in class alluxio.fuse.auth.CustomAuthPolicy
-
- getGid() - Method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
-
- getGid() - Method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
-
- getGid(String) - Method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
-
- getGid() - Method in class alluxio.fuse.file.CreateFileStatus
-
- getGidFromGroupName(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Retrieves the gid of the given group.
- getGidFromUserName(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Retrieves the primary gid of the given user.
- getGlobalStorageTierAssoc() - Method in interface alluxio.master.block.BlockMaster
-
- getGlobalStorageTierAssoc() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getGraceCycleSleepMs() - Method in class alluxio.master.StateLockOptions
-
- getGraceCycleTimeoutMs() - Method in class alluxio.master.StateLockOptions
-
- getGraceCycleTryMs() - Method in class alluxio.master.StateLockOptions
-
- getGraceMode() - Method in class alluxio.master.StateLockOptions
-
- getGroup() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getGroup() - Method in class alluxio.client.file.URIStatus
-
- getGroup() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string group = 17;
- getGroup() - Method in class alluxio.grpc.FileInfo
-
optional string group = 17;
- getGroup() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string group = 17;
- getGroup() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string group = 4;
- getGroup() - Method in class alluxio.grpc.SetAttributePOptions
-
optional string group = 4;
- getGroup() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional string group = 4;
- getGroup() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string group = 5;
- getGroup() - Method in class alluxio.grpc.UfsStatus
-
optional string group = 5;
- getGroup() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string group = 5;
- getGroup() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getGroup() - Method in class alluxio.master.file.meta.Inode
-
- getGroup() - Method in interface alluxio.master.file.meta.InodeView
-
- getGroup() - Method in class alluxio.master.file.meta.MutableInode
-
- getGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string group = 3;
- getGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional string group = 3;
- getGroup() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional string group = 3;
- getGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string group = 9;
- getGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string group = 9;
- getGroup() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string group = 9;
- getGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string group = 15;
- getGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string group = 15;
- getGroup() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string group = 15;
- getGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string group = 7;
- getGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string group = 7;
- getGroup() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string group = 7;
- getGroup() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string group = 10;
- getGroup() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string group = 10;
- getGroup() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string group = 10;
- getGroup() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
-
- getGroup() - Method in class alluxio.underfs.options.CreateOptions
-
- getGroup() - Method in class alluxio.underfs.options.MkdirsOptions
-
- getGroup() - Method in class alluxio.underfs.UfsStatus
-
Gets the group of the given path.
- getGroup(UserState, AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
-
- getGroup() - Method in class alluxio.util.webui.UIFileInfo
-
Gets group.
- getGroup() - Method in class alluxio.wire.FileInfo
-
- getGroupActions(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActions(int) - Method in class alluxio.proto.shared.Acl.AccessControlList
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActions(int) - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsCount() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsCount() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsCount() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsList() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsList() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsOrBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsOrBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsOrBuilder(int) - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsOrBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsOrBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupActionsOrBuilderList() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- getGroupBits() - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits groupBits = 2;
- getGroupBits() - Method in class alluxio.grpc.PMode
-
required .alluxio.grpc.Bits groupBits = 2;
- getGroupBits() - Method in interface alluxio.grpc.PModeOrBuilder
-
required .alluxio.grpc.Bits groupBits = 2;
- getGroupBits() - Method in class alluxio.security.authorization.Mode
-
- getGroupBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string group = 17;
- getGroupBytes() - Method in class alluxio.grpc.FileInfo
-
optional string group = 17;
- getGroupBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string group = 17;
- getGroupBytes() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string group = 4;
- getGroupBytes() - Method in class alluxio.grpc.SetAttributePOptions
-
optional string group = 4;
- getGroupBytes() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional string group = 4;
- getGroupBytes() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string group = 5;
- getGroupBytes() - Method in class alluxio.grpc.UfsStatus
-
optional string group = 5;
- getGroupBytes() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string group = 5;
- getGroupBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string group = 3;
- getGroupBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional string group = 3;
- getGroupBytes() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional string group = 3;
- getGroupBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string group = 9;
- getGroupBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string group = 9;
- getGroupBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string group = 9;
- getGroupBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string group = 15;
- getGroupBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string group = 15;
- getGroupBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string group = 15;
- getGroupBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string group = 7;
- getGroupBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string group = 7;
- getGroupBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string group = 7;
- getGroupBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string group = 10;
- getGroupBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string group = 10;
- getGroupBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string group = 10;
- getGroupFromGrpcClient(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
-
- getGroupName(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Gets the primary group name from the user name.
- getGroupName(long) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Gets the group name from the group id.
- getGroups(String) - Method in class alluxio.security.group.CachedGroupMapping
-
- getGroups(String) - Method in interface alluxio.security.group.GroupMappingService
-
Gets all various group memberships of a given user.
- getGroups(String) - Method in class alluxio.security.group.provider.IdentityUserGroupsMapping
-
Returns list of groups for a user.
- getGroups(String) - Method in class alluxio.security.group.provider.ShellBasedUnixGroupsMapping
-
Returns list of groups for a user.
- getGroups(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
-
- getGroupsForUserCommand(String) - Static method in class alluxio.util.ShellUtils
-
Gets a Unix command to get a given user's groups list.
- getGRpcBindAddress() - Method in class alluxio.worker.DataServerFactory
-
Get gRPC bind address.
- getGrpcFileInfo(String, long) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
-
- getGrpcMasterAddress(MasterInquireClient) - Method in interface alluxio.master.selectionpolicy.MasterSelectionPolicy
-
Gets the master address the client makes gRPC request to.
- getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicyAnyMaster
-
- getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
-
- getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicyPrimaryMaster
-
- getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicySpecifiedMaster
-
- getHadoopVersion() - Method in class alluxio.cli.hdfs.HdfsVersionValidationTask
-
- getHandler() - Method in class alluxio.metrics.sink.MetricsServlet
-
Gets the ServletContextHandler
of the metrics servlet.
- getHandler() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
-
Gets the ServletContextHandler
of the metrics servlet.
- getHasDirectChildrenLoaded() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool has_direct_children_loaded = 13;
- getHasDirectChildrenLoaded() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional bool has_direct_children_loaded = 13;
- getHasDirectChildrenLoaded() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional bool has_direct_children_loaded = 13;
- getHash() - Method in class alluxio.master.meta.PathPropertiesView
-
- getHdfsConfPaths() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
-
- getHeadDelay() - Method in class alluxio.util.executor.ControllableQueue
-
- getHeader(String) - Method in class alluxio.proxy.s3.S3Handler
-
get specified HTTP header value of this request.
- getHeader(String) - Method in class alluxio.worker.s3.S3NettyHandler
-
get specified HTTP header value of this request.
- getHeaderOrDefault(String, String) - Method in class alluxio.proxy.s3.S3Handler
-
get specified HTTP header with a default if not exist.
- getHeaderOrDefault(String, String) - Method in class alluxio.worker.s3.S3NettyHandler
-
get specified HTTP header with a default if not exist.
- getHeadValue() - Method in class alluxio.util.executor.ControllableQueue
-
- getHeartbeatMethod() - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
-
- getHelp() - Method in class alluxio.fuse.options.FuseCliOptions
-
- getHigh() - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value high = 2;
- getHigh() - Method in class alluxio.grpc.table.Range
-
optional .alluxio.grpc.table.Value high = 2;
- getHigh() - Method in interface alluxio.grpc.table.RangeOrBuilder
-
optional .alluxio.grpc.table.Value high = 2;
- getHighBuilder() - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value high = 2;
- getHighestTierAlias() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets highest tier alias.
- getHighOrBuilder() - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value high = 2;
- getHighOrBuilder() - Method in class alluxio.grpc.table.Range
-
optional .alluxio.grpc.table.Value high = 2;
- getHighOrBuilder() - Method in interface alluxio.grpc.table.RangeOrBuilder
-
optional .alluxio.grpc.table.Value high = 2;
- getHighValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date high_value = 2;
- getHighValue() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional .alluxio.grpc.table.Date high_value = 2;
- getHighValue() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Date high_value = 2;
- getHighValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- getHighValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- getHighValue() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- getHighValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional double high_value = 2;
- getHighValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional double high_value = 2;
- getHighValue() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional double high_value = 2;
- getHighValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 high_value = 2;
- getHighValue() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional int64 high_value = 2;
- getHighValue() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional int64 high_value = 2;
- getHighValueBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date high_value = 2;
- getHighValueBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- getHighValueOrBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date high_value = 2;
- getHighValueOrBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional .alluxio.grpc.table.Date high_value = 2;
- getHighValueOrBuilder() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Date high_value = 2;
- getHighValueOrBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- getHighValueOrBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- getHighValueOrBuilder() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- getHighWaterMark() - Method in class alluxio.master.metastore.caching.CacheConfiguration
-
- getHiveCacheContext() - Method in class alluxio.client.file.CacheContext
-
- getHost() - Method in class alluxio.cli.LogLevel.TargetInfo
-
- getHost() - Method in class alluxio.grpc.NetAddress.Builder
-
optional string host = 1;
- getHost() - Method in class alluxio.grpc.NetAddress
-
optional string host = 1;
- getHost() - Method in interface alluxio.grpc.NetAddressOrBuilder
-
optional string host = 1;
- getHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string host = 1;
- getHost() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string host = 1;
- getHost() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string host = 1;
- getHost() - Method in class alluxio.uri.SingleMasterAuthority
-
- getHost() - Method in class alluxio.util.webui.NodeInfo
-
Gets host.
- getHost() - Method in class alluxio.wire.Address
-
- getHost() - Method in class alluxio.wire.WorkerNetAddress
-
- getHost() - Method in class alluxio.worker.http.HttpRequestUri
-
Get the host name of the request URI.
- getHostBytes() - Method in class alluxio.grpc.NetAddress.Builder
-
optional string host = 1;
- getHostBytes() - Method in class alluxio.grpc.NetAddress
-
optional string host = 1;
- getHostBytes() - Method in interface alluxio.grpc.NetAddressOrBuilder
-
optional string host = 1;
- getHostBytes() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string host = 1;
- getHostBytes() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string host = 1;
- getHostBytes() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string host = 1;
- getHostName() - Method in class alluxio.grpc.GrpcServerAddress
-
- getHostname() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional string hostname = 4;
- getHostname() - Method in class alluxio.grpc.JobWorkerHealth
-
optional string hostname = 4;
- getHostname() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional string hostname = 4;
- getHostname() - Method in class alluxio.job.wire.JobWorkerHealth
-
- getHostname() - Method in class alluxio.master.LocalAlluxioCluster
-
- getHostname() - Method in class alluxio.master.LocalAlluxioJobCluster
-
- getHostname() - Method in class alluxio.multi.process.MasterNetAddress
-
- getHostName() - Method in class alluxio.shell.ScpCommand
-
Returns the remote target hostname.
- getHostName() - Method in class alluxio.shell.SshCommand
-
Returns the remote target hostname.
- getHostname() - Method in class alluxio.wire.BackupStatus
-
- getHostnameBytes() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional string hostname = 4;
- getHostnameBytes() - Method in class alluxio.grpc.JobWorkerHealth
-
optional string hostname = 4;
- getHostnameBytes() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional string hostname = 4;
- getHostNameKey() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
-
Gets the key of connect hostname.
- getHostNameKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
-
Gets the key of connect hostname.
- getHosts() - Method in class alluxio.cli.bundler.CollectInfo
-
Finds all hosts in the Alluxio cluster.
- getHttpMethod() - Method in class alluxio.worker.s3.S3NettyHandler
-
get HTTP verb of this request.
- getHttpResponse() - Method in class alluxio.worker.http.HttpResponseContext
-
Get the http response.
- getHTTPVerb() - Method in class alluxio.proxy.s3.S3Handler
-
get HTTP verb of this request.
- getId() - Method in class alluxio.client.file.FileSystemContext
-
- getId() - Method in class alluxio.fuse.CreateFileEntry
-
- getId() - Method in class alluxio.fuse.file.FuseFileEntry
-
- getId() - Method in class alluxio.fuse.OpenFileEntry
-
- getId() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
-
optional int64 id = 1;
- getId() - Method in interface alluxio.grpc.GetNewBlockIdForFilePResponseOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.grpc.JobInfo
-
optional int64 id = 1;
- getId() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.grpc.PolicyInfo
-
optional int64 id = 1;
- getId() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
-
optional int64 id = 1;
- getId() - Method in interface alluxio.grpc.RegisterJobWorkerPResponseOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional uint32 id = 1;
- getId() - Method in class alluxio.grpc.table.FieldSchema
-
optional uint32 id = 1;
- getId() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional uint32 id = 1;
- getId() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.grpc.WorkerInfo
-
optional int64 id = 1;
- getId() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
The block ID or UFS file ID.
- getId() - Method in class alluxio.grpc.WriteRequestCommand
-
The block ID or UFS file ID.
- getId() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
The block ID or UFS file ID.
- getId() - Method in class alluxio.job.MasterWorkerInfo
-
- getId() - Method in class alluxio.job.plan.meta.PlanInfo
-
- getId() - Method in interface alluxio.job.wire.JobInfo
-
- getId() - Method in class alluxio.job.wire.PlanInfo
-
- getId() - Method in class alluxio.job.wire.TaskInfo
-
- getId() - Method in class alluxio.job.wire.WorkflowInfo
-
- getId() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
No locking required.
- getId() - Method in class alluxio.master.file.meta.Edge
-
- getId() - Method in class alluxio.master.file.meta.Inode
-
- getId() - Method in interface alluxio.master.file.meta.InodeView
-
- getId() - Method in class alluxio.master.file.meta.MutableInode
-
- getId() - Method in class alluxio.master.file.PersistJob
-
- getId() - Method in enum alluxio.master.journal.checkpoint.CheckpointType
-
- getId() - Method in class alluxio.master.meta.JobMasterInfo
-
- getId() - Method in class alluxio.master.meta.MasterInfo
-
- getId(Address) - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
-
Returns a master id for a master address.
- getId(Address) - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
-
Returns a master id for a master address.
- getId() - Method in class alluxio.master.metastore.BlockMetaStore.Block
-
- getId() - Method in enum alluxio.network.protocol.RPCMessage.Type
-
Returns the int identifier of the type.
- getId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
The block ID or UFS file ID.
- getId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
The block ID or UFS file ID.
- getId() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
The block ID or UFS file ID.
- getId() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 id = 2;
- getId() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
optional int64 id = 2;
- getId() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
optional int64 id = 2;
- getId() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.NewBlockEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.NewBlockEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.PersistDirectoryEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.SetAclEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 id = 1;
- getId() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 id = 1;
- getId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 id = 1;
- getID() - Method in class alluxio.util.webui.UIFileBlockInfo
-
Gets id.
- getId() - Method in class alluxio.util.webui.UIFileInfo
-
Gets id.
- getId() - Method in class alluxio.util.webui.UIMasterInfo
-
Get id.
- getId() - Method in class alluxio.wire.BlockReadRequest
-
- getId() - Method in class alluxio.wire.MasterInfo
-
- getId() - Method in class alluxio.wire.WorkerInfo
-
- getId(WorkerNetAddress) - Method in class alluxio.worker.block.BlockMasterClient
-
Returns a worker id for a workers net address.
- getId() - Method in class alluxio.worker.grpc.WriteRequest
-
- getId() - Method in class alluxio.worker.netty.ReadRequest
-
- getIdentifier() - Method in class alluxio.client.file.cache.CacheUsage.DirPartition
-
- getIdentifier() - Method in class alluxio.client.file.cache.CacheUsage.FilePartition
-
- getIdentifier() - Method in interface alluxio.client.file.cache.CacheUsage.PartitionDescriptor
-
Gets an identifier of the partition.
- getIdentifier() - Method in class alluxio.client.file.cache.CacheUsage.ScopePartition
-
- getIdentifier() - Method in class alluxio.grpc.WorkerIdentity.Builder
-
exactly how this byte sequence is interpreted depends on the version of its definition
- getIdentifier() - Method in class alluxio.grpc.WorkerIdentity
-
exactly how this byte sequence is interpreted depends on the version of its definition
- getIdentifier() - Method in interface alluxio.grpc.WorkerIdentityOrBuilder
-
exactly how this byte sequence is interpreted depends on the version of its definition
- getIdentifier() - Method in class alluxio.master.file.meta.xattr.AbstractExtendedAttribute
-
- getIdentifier() - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
-
- getIgnoreClusterConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool ignoreClusterConf = 2;
- getIgnoreClusterConf() - Method in class alluxio.grpc.GetConfigurationPOptions
-
optional bool ignoreClusterConf = 2;
- getIgnoreClusterConf() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
-
optional bool ignoreClusterConf = 2;
- getIgnorePathConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool ignorePathConf = 3;
- getIgnorePathConf() - Method in class alluxio.grpc.GetConfigurationPOptions
-
optional bool ignorePathConf = 3;
- getIgnorePathConf() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
-
optional bool ignorePathConf = 3;
- getIgnoreSyncErrors() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional bool ignore_sync_errors = 6;
- getIgnoreSyncErrors() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional bool ignore_sync_errors = 6;
- getIgnoreSyncErrors() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional bool ignore_sync_errors = 6;
- getImpersonationAuthenticator() - Method in class alluxio.security.authentication.DefaultAuthenticationServer
-
- getImpersonationUser(Subject, AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticationUtils
-
- getIn() - Method in class alluxio.fuse.OpenFileEntry
-
Gets the opened input stream for this open file entry.
- getInAlluxio() - Method in class alluxio.util.webui.UIFileInfo
-
Gets in alluxio.
- getInAlluxioFileNum() - Method in class alluxio.wire.MasterWebUIData
-
Gets in alluxio file num.
- getInAlluxioFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getInAlluxioFiles() - Method in interface alluxio.master.file.FileSystemMaster
-
- getInAlluxioPercentage() - Method in class alluxio.client.file.URIStatus
-
- getInAlluxioPercentage() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 inAlluxioPercentage = 24;
- getInAlluxioPercentage() - Method in class alluxio.grpc.FileInfo
-
optional int32 inAlluxioPercentage = 24;
- getInAlluxioPercentage() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int32 inAlluxioPercentage = 24;
- getInAlluxioPercentage() - Method in class alluxio.util.webui.UIFileInfo
-
Gets in alluxio percentage.
- getInAlluxioPercentage() - Method in class alluxio.wire.FileInfo
-
- getIncludeRealContentHash() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional bool includeRealContentHash = 5;
- getIncludeRealContentHash() - Method in class alluxio.grpc.GetStatusPOptions
-
optional bool includeRealContentHash = 5;
- getIncludeRealContentHash() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional bool includeRealContentHash = 5;
- getInconsistentPaths(int) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
repeated string inconsistentPaths = 1;
- getInconsistentPaths(int) - Method in class alluxio.grpc.CheckConsistencyPResponse
-
repeated string inconsistentPaths = 1;
- getInconsistentPaths(int) - Method in interface alluxio.grpc.CheckConsistencyPResponseOrBuilder
-
repeated string inconsistentPaths = 1;
- getInconsistentPathsBytes(int) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
repeated string inconsistentPaths = 1;
- getInconsistentPathsBytes(int) - Method in class alluxio.grpc.CheckConsistencyPResponse
-
repeated string inconsistentPaths = 1;
- getInconsistentPathsBytes(int) - Method in interface alluxio.grpc.CheckConsistencyPResponseOrBuilder
-
repeated string inconsistentPaths = 1;
- getInconsistentPathsCount() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
repeated string inconsistentPaths = 1;
- getInconsistentPathsCount() - Method in class alluxio.grpc.CheckConsistencyPResponse
-
repeated string inconsistentPaths = 1;
- getInconsistentPathsCount() - Method in interface alluxio.grpc.CheckConsistencyPResponseOrBuilder
-
repeated string inconsistentPaths = 1;
- getInconsistentPathsList() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
repeated string inconsistentPaths = 1;
- getInconsistentPathsList() - Method in class alluxio.grpc.CheckConsistencyPResponse
-
repeated string inconsistentPaths = 1;
- getInconsistentPathsList() - Method in interface alluxio.grpc.CheckConsistencyPResponseOrBuilder
-
repeated string inconsistentPaths = 1;
- getIncreasingByteArray(int) - Static method in class alluxio.util.io.BufferUtils
-
Gets an increasing sequence of bytes starting at zero.
- getIncreasingByteArray(int, int) - Static method in class alluxio.util.io.BufferUtils
-
Gets an increasing sequence of bytes starting with the given value.
- getIncreasingByteBuffer(int) - Static method in class alluxio.util.io.BufferUtils
-
Gets a
ByteBuffer
containing an increasing sequence of bytes starting at zero.
- getIncreasingByteBuffer(int, int) - Static method in class alluxio.util.io.BufferUtils
-
Gets a
ByteBuffer
containing an increasing sequence of bytes starting at the given
value.
- getIndex() - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- getInfo(long) - Method in class alluxio.client.block.BlockStoreClient
-
Gets the block info of a block, if it exists.
- getInfo(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfo(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfo(int) - Method in interface alluxio.grpc.table.GetTransformJobInfoPResponseOrBuilder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfo(Boolean) - Method in class alluxio.master.AlluxioJobMasterRestServiceHandler
-
- getInfo(Boolean) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
- getInfo(Boolean) - Method in class alluxio.proxy.AlluxioProxyRestServiceHandler
-
- getInfo(Boolean) - Method in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
-
- getInfo() - Method in class alluxio.worker.dora.OpenFileHandle
-
Get info of this handle.
- getInfoBuilder(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoBuilderList() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoCount() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoCount() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoCount() - Method in interface alluxio.grpc.table.GetTransformJobInfoPResponseOrBuilder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoList() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoList() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoList() - Method in interface alluxio.grpc.table.GetTransformJobInfoPResponseOrBuilder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoOrBuilder(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoOrBuilder(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoOrBuilder(int) - Method in interface alluxio.grpc.table.GetTransformJobInfoPResponseOrBuilder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoOrBuilderList() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoOrBuilderList() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfoOrBuilderList() - Method in interface alluxio.grpc.table.GetTransformJobInfoPResponseOrBuilder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- getInfos(int) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfos(int) - Method in class alluxio.grpc.GetActionInfoResponse
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfos(int) - Method in interface alluxio.grpc.GetActionInfoResponseOrBuilder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosBuilder(int) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosBuilderList() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosCount() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosCount() - Method in class alluxio.grpc.GetActionInfoResponse
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosCount() - Method in interface alluxio.grpc.GetActionInfoResponseOrBuilder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosList() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosList() - Method in class alluxio.grpc.GetActionInfoResponse
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosList() - Method in interface alluxio.grpc.GetActionInfoResponseOrBuilder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosOrBuilder(int) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosOrBuilder(int) - Method in class alluxio.grpc.GetActionInfoResponse
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosOrBuilder(int) - Method in interface alluxio.grpc.GetActionInfoResponseOrBuilder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosOrBuilderList() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosOrBuilderList() - Method in class alluxio.grpc.GetActionInfoResponse
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfosOrBuilderList() - Method in interface alluxio.grpc.GetActionInfoResponseOrBuilder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- getInfoTimeExceeded() - Method in class alluxio.util.JvmPauseMonitor
-
- getInitialBytes() - Method in class alluxio.worker.block.CreateBlockOptions
-
- getInitialDelayMs() - Method in class alluxio.resource.DynamicResourcePool.Options
-
- getInitiated() - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
-
- getInMemoryFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getInMemoryFiles() - Method in interface alluxio.master.file.FileSystemMaster
-
- getInMemoryPercentage() - Method in class alluxio.client.file.URIStatus
-
- getInMemoryPercentage() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 inMemoryPercentage = 25;
- getInMemoryPercentage() - Method in class alluxio.grpc.FileInfo
-
optional int32 inMemoryPercentage = 25;
- getInMemoryPercentage() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int32 inMemoryPercentage = 25;
- getInMemoryPercentage() - Method in class alluxio.wire.FileInfo
-
- getInode() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getInodeCount() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getInodeCount() - Method in interface alluxio.master.file.FileSystemMaster
-
Get the total inode count.
- getInodeCount() - Method in class alluxio.master.file.meta.InodeTree
-
- getInodeCount() - Method in class alluxio.master.file.meta.InodeTreePersistentState
-
- getInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- getInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- getInodeDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- getInodeDirectoryBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- getInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- getInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- getInodeDirectoryIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- getInodeDirectoryIdGeneratorBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- getInodeDirectoryIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- getInodeDirectoryIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- getInodeDirectoryIdGeneratorOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- getInodeDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- getInodeDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- getInodeDirectoryOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- getInodeExpiries() - Method in class alluxio.master.file.meta.TtlBucket
-
Get collection of inode to its left ttl process retry attempts.
- getInodeFile() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- getInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- getInodeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- getInodeFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- getInodeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- getInodeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- getInodeFileOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- getInodeIds() - Method in class alluxio.master.file.meta.TtlBucket
-
- getInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- getInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- getInodeLastModificationTime() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- getInodeLastModificationTimeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- getInodeLastModificationTimeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- getInodeLastModificationTimeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- getInodeLastModificationTimeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- getInodeList() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getInodeLockManager() - Method in class alluxio.master.file.meta.CompositeInodeLockList
-
- getInodeLockManager() - Method in interface alluxio.master.file.meta.InodeLockList
-
- getInodeLockManager() - Method in class alluxio.master.file.meta.InodeTree
-
- getInodeLockManager() - Method in class alluxio.master.file.meta.SimpleInodeLockList
-
- getInodeOrNull() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getInodePathList() - Method in class alluxio.master.file.meta.LockedInodePathList
-
get the associated inodePathList.
- getInodePathString(InodeView) - Method in interface alluxio.master.metastore.InodeStore
-
Traverses the inode path starting from the given inode up to the root.
- getInodeStoreFactory() - Method in class alluxio.master.CoreMasterContext
-
- getInodeStoreFactory(String) - Static method in class alluxio.master.MasterUtils
-
- getInodeViewList() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getInputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string input_format = 2;
- getInputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
optional string input_format = 2;
- getInputFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
optional string input_format = 2;
- getInputFormatBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string input_format = 2;
- getInputFormatBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
optional string input_format = 2;
- getInputFormatBytes() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
optional string input_format = 2;
- getInputStream() - Method in class alluxio.proxy.s3.S3Handler
-
retrieve inputstream from incoming request.
- getInputStream(String, Integer) - Static method in class alluxio.util.network.HttpUtils
-
Uses the get method to send a url with arguments by http, this method can call RESTful Api.
- getInstance() - Method in class alluxio.grpc.Metric.Builder
-
optional string instance = 1;
- getInstance() - Method in class alluxio.grpc.Metric
-
optional string instance = 1;
- getInstance() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional string instance = 1;
- getInstance() - Static method in class alluxio.jnifuse.utils.NativeLibraryLoader
-
Get a reference to the NativeLibraryLoader.
- getInstance() - Static method in class alluxio.master.scheduler.Scheduler
-
Get the singleton instance of Scheduler.
- getInstance(AlluxioConfiguration) - Static method in class alluxio.membership.AlluxioEtcdClient
-
Get the singleton instance of AlluxioEtcdClient.
- getInstance() - Static method in class alluxio.proxy.s3.MultipartUploadCleaner
-
- getInstanceBytes() - Method in class alluxio.grpc.Metric.Builder
-
optional string instance = 1;
- getInstanceBytes() - Method in class alluxio.grpc.Metric
-
optional string instance = 1;
- getInstanceBytes() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional string instance = 1;
- getInstanceType() - Method in class alluxio.metrics.Metric
-
- getInstanceType() - Method in class alluxio.metrics.MetricsFilter
-
- getInStream(URIStatus, Protocol.OpenUfsBlockOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
-
Get a stream to read the data from dora cache cluster.
- getInStream(Integer) - Method in class alluxio.StreamCache
-
- getInt(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the integer representation of the value for the given key.
- getInt(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the integer representation of the value for the given key.
- getInt(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getInt(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getIntArg(CommandLine, Option, int) - Static method in class alluxio.cli.fs.FileSystemShellUtils
-
Gets the value of an option from the command line.
- getInterval() - Method in class alluxio.util.WaitForOptions
-
- getIntervals() - Method in class alluxio.master.predicate.interval.IntervalSet
-
- getInvalidPathError() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets invalid path error.
- getInvalidPathError() - Method in class alluxio.wire.MasterWebUILogs
-
Gets invalid path error.
- getInvalidPathError() - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Gets invalid path error.
- getInvalidPathError() - Method in class alluxio.wire.WorkerWebUILogs
-
Gets invalid path error.
- getInvalidPathException() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets invalid path exception.
- getIOBytes() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- getIOBytes() - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- getIOBytes() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- getIOMBps() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- getIOMBps() - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- getIpAddress() - Static method in class alluxio.security.authentication.ClientContextServerInjector
-
- getIsAtomicWrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool isAtomicWrite = 16;
- getIsAtomicWrite() - Method in class alluxio.grpc.CreateFilePOptions
-
optional bool isAtomicWrite = 16;
- getIsAtomicWrite() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional bool isAtomicWrite = 16;
- getIsCacheable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_cacheable = 17;
- getIsCacheable() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional bool is_cacheable = 17;
- getIsCacheable() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional bool is_cacheable = 17;
- getIsCompleted() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_completed = 18;
- getIsCompleted() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional bool is_completed = 18;
- getIsCompleted() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional bool is_completed = 18;
- getIsDefault() - Method in class alluxio.grpc.PAcl.Builder
-
optional bool isDefault = 5;
- getIsDefault() - Method in class alluxio.grpc.PAcl
-
optional bool isDefault = 5;
- getIsDefault() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional bool isDefault = 4;
- getIsDefault() - Method in class alluxio.grpc.PAclEntry
-
optional bool isDefault = 4;
- getIsDefault() - Method in interface alluxio.grpc.PAclEntryOrBuilder
-
optional bool isDefault = 4;
- getIsDefault() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional bool isDefault = 5;
- getIsDefault() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional bool isDefault = 7;
- getIsDefault() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional bool isDefault = 7;
- getIsDefault() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional bool isDefault = 7;
- getIsDefault() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional bool isDefault = 4;
- getIsDefault() - Method in class alluxio.proto.shared.Acl.AclEntry
-
optional bool isDefault = 4;
- getIsDefault() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
-
optional bool isDefault = 4;
- getIsDefaultEmpty() - Method in class alluxio.grpc.PAcl.Builder
-
optional bool isDefaultEmpty = 6;
- getIsDefaultEmpty() - Method in class alluxio.grpc.PAcl
-
optional bool isDefaultEmpty = 6;
- getIsDefaultEmpty() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional bool isDefaultEmpty = 6;
- getIsDirectory() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional bool is_directory = 2;
- getIsDirectory() - Method in class alluxio.grpc.UfsStatus
-
optional bool is_directory = 2;
- getIsDirectory() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional bool is_directory = 2;
- getIsDirectory() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_directory = 3;
- getIsDirectory() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional bool is_directory = 3;
- getIsDirectory() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional bool is_directory = 3;
- getIsDirectory() - Method in class alluxio.util.webui.UIFileInfo
-
Gets is directory.
- getIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional bool isEmpty = 8;
- getIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional bool isEmpty = 8;
- getIsEmpty() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional bool isEmpty = 8;
- getIsLeader() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional bool isLeader = 3;
- getIsLeader() - Method in class alluxio.grpc.QuorumServerInfo
-
optional bool isLeader = 3;
- getIsLeader() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
-
optional bool isLeader = 3;
- getIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
directory only
- getIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
directory only
- getIsMountPoint() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
directory only
- getIsMultipartUpload() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
optional bool isMultipartUpload = 2;
- getIsMultipartUpload() - Method in class alluxio.grpc.S3SyntaxOptions
-
optional bool isMultipartUpload = 2;
- getIsMultipartUpload() - Method in interface alluxio.grpc.S3SyntaxOptionsOrBuilder
-
optional bool isMultipartUpload = 2;
- getIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_pinned = 9;
- getIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional bool is_pinned = 9;
- getIsPinned() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional bool is_pinned = 9;
- getIsRetryable() - Method in class alluxio.grpc.RetryInfo.Builder
-
optional bool isRetryable = 1;
- getIsRetryable() - Method in class alluxio.grpc.RetryInfo
-
optional bool isRetryable = 1;
- getIsRetryable() - Method in interface alluxio.grpc.RetryInfoOrBuilder
-
optional bool isRetryable = 1;
- getIsScanning() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional bool isScanning = 11;
- getIsScanning() - Method in class alluxio.grpc.PolicyStatus
-
optional bool isScanning = 11;
- getIsScanning() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional bool isScanning = 11;
- getIsSkip() - Method in class alluxio.grpc.RouteFailure.Builder
-
optional bool is_skip = 5;
- getIsSkip() - Method in class alluxio.grpc.RouteFailure
-
optional bool is_skip = 5;
- getIsSkip() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
optional bool is_skip = 5;
- getIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
optional bool isThrowable = 2;
- getIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader
-
optional bool isThrowable = 2;
- getIsThrowable() - Method in interface alluxio.grpc.MessagingResponseHeaderOrBuilder
-
optional bool isThrowable = 2;
- getIsTruncated() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
True if the partial listing was truncated.
- getIsTruncated() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
True if the partial listing was truncated.
- getIsTruncated() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
-
True if the partial listing was truncated.
- getIsttfb() - Method in class alluxio.stress.cli.Benchmark.ProfileInput
-
- getItems() - Method in class alluxio.underfs.UfsLoadResult
-
- getItemsCount() - Method in class alluxio.underfs.UfsLoadResult
-
- getJavaVersion() - Static method in class alluxio.util.CommonUtils
-
- getJniLibraryExtension() - Static method in class alluxio.jnifuse.utils.Environment
-
- getJniLibraryFileName(String) - Static method in class alluxio.jnifuse.utils.Environment
-
- getJniLibraryName(String) - Static method in class alluxio.jnifuse.utils.Environment
-
- getJob() - Method in class alluxio.scheduler.job.Task
-
Get the job this task belongs to.
- getJobConfig() - Method in class alluxio.cli.fs.command.job.JobAttempt
-
Get job config.
- getJobConfig() - Method in class alluxio.grpc.RunPRequest.Builder
-
optional bytes jobConfig = 1;
- getJobConfig() - Method in class alluxio.grpc.RunPRequest
-
optional bytes jobConfig = 1;
- getJobConfig() - Method in interface alluxio.grpc.RunPRequestOrBuilder
-
optional bytes jobConfig = 1;
- getJobConfig() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional bytes jobConfig = 3;
- getJobConfig() - Method in class alluxio.grpc.RunTaskCommand
-
optional bytes jobConfig = 3;
- getJobConfig() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
-
optional bytes jobConfig = 3;
- getJobConfig() - Method in class alluxio.job.plan.batch.BatchedJobDefinition.BatchedJobTask
-
- getJobConfig() - Method in class alluxio.job.plan.meta.PlanInfo
-
- getJobConfig() - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Get job config.
- getJobConfigClass() - Method in class alluxio.job.plan.batch.BatchedJobDefinition
-
- getJobConfigClass() - Method in class alluxio.job.plan.migrate.MigrateDefinition
-
- getJobConfigClass() - Method in class alluxio.job.plan.NoopPlanDefinition
-
- getJobConfigClass() - Method in class alluxio.job.plan.persist.PersistDefinition
-
- getJobConfigClass() - Method in interface alluxio.job.plan.PlanDefinition
-
- getJobConfigClass() - Method in class alluxio.job.plan.replicate.MoveDefinition
-
- getJobConfigClass() - Method in class alluxio.job.plan.stress.StressBenchDefinition
-
- getJobConfigs() - Method in class alluxio.job.plan.BatchedJobConfig
-
- getJobControlId() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in class alluxio.grpc.CmdStatusBlock
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in class alluxio.grpc.CmdSummary
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in interface alluxio.grpc.GetCmdStatusDetailedRequestOrBuilder
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in class alluxio.grpc.GetCmdStatusRequest
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in interface alluxio.grpc.GetCmdStatusRequestOrBuilder
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in class alluxio.grpc.SubmitResponse.Builder
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in class alluxio.grpc.SubmitResponse
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in interface alluxio.grpc.SubmitResponseOrBuilder
-
optional int64 jobControlId = 1;
- getJobControlId() - Method in class alluxio.job.wire.CmdStatusBlock
-
Get job control ID of the command.
- getJobControlId() - Method in class alluxio.master.job.common.CmdInfo
-
Get job control Id.
- getJobDefinition(T) - Method in enum alluxio.job.plan.PlanDefinitionRegistry
-
Gets the job definition from the job configuration.
- getJobDescription() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescription() - Method in class alluxio.grpc.GetJobProgressPRequest
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescription() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescription() - Method in class alluxio.grpc.StopJobPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescription() - Method in class alluxio.grpc.StopJobPRequest
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescription() - Method in interface alluxio.grpc.StopJobPRequestOrBuilder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescriptionBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescriptionBuilder() - Method in class alluxio.grpc.StopJobPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescriptionOrBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescriptionOrBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescriptionOrBuilder() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescriptionOrBuilder() - Method in class alluxio.grpc.StopJobPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescriptionOrBuilder() - Method in class alluxio.grpc.StopJobPRequest
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobDescriptionOrBuilder() - Method in interface alluxio.grpc.StopJobPRequestOrBuilder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- getJobError() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string job_error = 6;
- getJobError() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string job_error = 6;
- getJobError() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string job_error = 6;
- getJobErrorBytes() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string job_error = 6;
- getJobErrorBytes() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string job_error = 6;
- getJobErrorBytes() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string job_error = 6;
- getJobId() - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.CancelPRequest
-
optional int64 jobId = 1;
- getJobId() - Method in interface alluxio.grpc.CancelPRequestOrBuilder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.CancelTaskCommand
-
optional int64 jobId = 1;
- getJobId() - Method in interface alluxio.grpc.CancelTaskCommandOrBuilder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
optional int64 jobId = 1;
- getJobId() - Method in interface alluxio.grpc.GetJobStatusDetailedPRequestOrBuilder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.GetJobStatusPRequest
-
optional int64 jobId = 1;
- getJobId() - Method in interface alluxio.grpc.GetJobStatusPRequestOrBuilder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.JobProgress
-
optional int64 jobId = 1;
- getJobId() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.JobStatusBlock
-
optional int64 jobId = 1;
- getJobId() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.RunPResponse.Builder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.RunPResponse
-
optional int64 jobId = 1;
- getJobId() - Method in interface alluxio.grpc.RunPResponseOrBuilder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.RunTaskCommand
-
optional int64 jobId = 1;
- getJobId() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
-
optional int64 jobId = 1;
- getJobId() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
optional string jobId = 1;
- getJobId() - Method in class alluxio.grpc.SubmitJobPResponse
-
optional string jobId = 1;
- getJobId() - Method in interface alluxio.grpc.SubmitJobPResponseOrBuilder
-
optional string jobId = 1;
- getJobId() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
optional int64 job_id = 1;
- getJobId() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
-
optional int64 job_id = 1;
- getJobId() - Method in interface alluxio.grpc.table.GetTransformJobInfoPRequestOrBuilder
-
optional int64 job_id = 1;
- getJobId() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional int64 job_id = 4;
- getJobId() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional int64 job_id = 4;
- getJobId() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional int64 job_id = 4;
- getJobId() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
optional int64 job_id = 1;
- getJobId() - Method in class alluxio.grpc.table.TransformTablePResponse
-
optional int64 job_id = 1;
- getJobId() - Method in interface alluxio.grpc.table.TransformTablePResponseOrBuilder
-
optional int64 job_id = 1;
- getJobId() - Method in class alluxio.job.RunTaskContext
-
- getJobId() - Method in class alluxio.job.SelectExecutorsContext
-
- getJobId() - Method in class alluxio.job.wire.SimpleJobStatusBlock
-
Get job id.
- getJobId() - Method in class alluxio.job.wire.TaskInfo
-
- getJobId() - Method in class alluxio.master.job.AbstractJob
-
- getJobId() - Method in class alluxio.master.job.plan.PlanCoordinator
-
- getJobId() - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Returns the job Id.
- getJobId() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string job_id = 8;
- getJobId() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required string job_id = 8;
- getJobId() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required string job_id = 8;
- getJobId() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string job_id = 7;
- getJobId() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required string job_id = 7;
- getJobId() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required string job_id = 7;
- getJobId() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string job_id = 8;
- getJobId() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required string job_id = 8;
- getJobId() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required string job_id = 8;
- getJobId() - Method in interface alluxio.scheduler.job.Job
-
- getJobIdBytes() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
optional string jobId = 1;
- getJobIdBytes() - Method in class alluxio.grpc.SubmitJobPResponse
-
optional string jobId = 1;
- getJobIdBytes() - Method in interface alluxio.grpc.SubmitJobPResponseOrBuilder
-
optional string jobId = 1;
- getJobIdBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string job_id = 8;
- getJobIdBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required string job_id = 8;
- getJobIdBytes() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required string job_id = 8;
- getJobIdBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string job_id = 7;
- getJobIdBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required string job_id = 7;
- getJobIdBytes() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required string job_id = 7;
- getJobIdBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string job_id = 8;
- getJobIdBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required string job_id = 8;
- getJobIdBytes() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required string job_id = 8;
- getJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional bool jobIdOnly = 3;
- getJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions
-
optional bool jobIdOnly = 3;
- getJobIdOnly() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
-
optional bool jobIdOnly = 3;
- getJobIds(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated int64 jobIds = 1;
- getJobIds(int) - Method in class alluxio.grpc.ListAllPResponse
-
repeated int64 jobIds = 1;
- getJobIds(int) - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
-
repeated int64 jobIds = 1;
- getJobIdsCount() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated int64 jobIds = 1;
- getJobIdsCount() - Method in class alluxio.grpc.ListAllPResponse
-
repeated int64 jobIds = 1;
- getJobIdsCount() - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
-
repeated int64 jobIds = 1;
- getJobIdsList() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated int64 jobIds = 1;
- getJobIdsList() - Method in class alluxio.grpc.ListAllPResponse
-
repeated int64 jobIds = 1;
- getJobIdsList() - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
-
repeated int64 jobIds = 1;
- getJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfo() - Method in interface alluxio.grpc.GetJobStatusDetailedPResponseOrBuilder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfo() - Method in interface alluxio.grpc.GetJobStatusPResponseOrBuilder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfoBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfoBuilder() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfoOrBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfoOrBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfoOrBuilder() - Method in interface alluxio.grpc.GetJobStatusDetailedPResponseOrBuilder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfoOrBuilder() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfoOrBuilder() - Method in class alluxio.grpc.GetJobStatusPResponse
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfoOrBuilder() - Method in interface alluxio.grpc.GetJobStatusPResponseOrBuilder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- getJobInfos(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfos(int) - Method in class alluxio.grpc.ListAllPResponse
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfos(int) - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosBuilder(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosBuilderList() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosCount() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosCount() - Method in class alluxio.grpc.ListAllPResponse
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosCount() - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosList() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosList() - Method in class alluxio.grpc.ListAllPResponse
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosList() - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosOrBuilder(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosOrBuilder(int) - Method in class alluxio.grpc.ListAllPResponse
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosOrBuilder(int) - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosOrBuilderList() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosOrBuilderList() - Method in class alluxio.grpc.ListAllPResponse
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobInfosOrBuilderList() - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- getJobMaster() - Method in class alluxio.master.AlluxioJobMasterProcess
-
- getJobMasterAddress() - Method in class alluxio.client.job.JobContext
-
- getJobMasterClient() - Method in class alluxio.cli.fsadmin.command.Context
-
- getJobMasterEmbeddedJournalAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
-
- getJobMasterHostNotConfiguredMessage(String) - Static method in class alluxio.util.ConfigurationUtils
-
Returns a unified message for cases when the job master hostname cannot be determined.
- getJobMasterId() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional int64 jobMasterId = 1;
- getJobMasterId() - Method in class alluxio.grpc.RegisterJobMasterPRequest
-
optional int64 jobMasterId = 1;
- getJobMasterId() - Method in interface alluxio.grpc.RegisterJobMasterPRequestOrBuilder
-
optional int64 jobMasterId = 1;
- GetJobMasterIdPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobMasterIdPOptions
- GetJobMasterIdPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobMasterIdPOptions
- GetJobMasterIdPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetJobMasterIdPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobMasterIdPRequest
- GetJobMasterIdPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobMasterIdPRequest
- GetJobMasterIdPRequestOrBuilder - Interface in alluxio.grpc
-
- GetJobMasterIdPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobMasterIdPResponse
- GetJobMasterIdPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobMasterIdPResponse
- GetJobMasterIdPResponseOrBuilder - Interface in alluxio.grpc
-
- getJobMasterRpcAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
-
Gets the RPC addresses of all job masters based on the configuration.
- getJobMasterStatus(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatus(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatus(int) - Method in interface alluxio.grpc.GetAllMasterStatusPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusBuilder(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusBuilderList() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusCount() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusCount() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusCount() - Method in interface alluxio.grpc.GetAllMasterStatusPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusList() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusList() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusList() - Method in interface alluxio.grpc.GetAllMasterStatusPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusOrBuilder(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusOrBuilder(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusOrBuilder(int) - Method in interface alluxio.grpc.GetAllMasterStatusPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusOrBuilderList() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusOrBuilderList() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMasterStatusOrBuilderList() - Method in interface alluxio.grpc.GetAllMasterStatusPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- getJobMetaStore() - Method in class alluxio.master.scheduler.Scheduler
-
Get job meta store.
- getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in class alluxio.client.file.DelegatingFileSystem
-
- getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in interface alluxio.client.file.FileSystem
-
Get progress of a job.
- getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Get progress of a job.
- getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- getJobProgress(int) - Method in class alluxio.grpc.CmdProgress.Builder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgress(int) - Method in class alluxio.grpc.CmdProgress
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgress(int) - Method in interface alluxio.grpc.CmdProgressOrBuilder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgress(GetJobProgressPRequest, StreamObserver<GetJobProgressPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
- getJobProgress(GetJobProgressPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
- getJobProgress(GetJobProgressPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
- getJobProgress(GetJobProgressPRequest, StreamObserver<GetJobProgressPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
- getJobProgress(GetJobProgressPRequest, StreamObserver<GetJobProgressPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in class alluxio.master.scheduler.Scheduler
-
Get the job's progress report.
- getJobProgressBuilder(int) - Method in class alluxio.grpc.CmdProgress.Builder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressBuilderList() - Method in class alluxio.grpc.CmdProgress.Builder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressCount() - Method in class alluxio.grpc.CmdProgress.Builder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressCount() - Method in class alluxio.grpc.CmdProgress
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressCount() - Method in interface alluxio.grpc.CmdProgressOrBuilder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressList() - Method in class alluxio.grpc.CmdProgress.Builder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressList() - Method in class alluxio.grpc.CmdProgress
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressList() - Method in interface alluxio.grpc.CmdProgressOrBuilder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressOrBuilder(int) - Method in class alluxio.grpc.CmdProgress.Builder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressOrBuilder(int) - Method in class alluxio.grpc.CmdProgress
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressOrBuilder(int) - Method in interface alluxio.grpc.CmdProgressOrBuilder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressOrBuilderList() - Method in class alluxio.grpc.CmdProgress.Builder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressOrBuilderList() - Method in class alluxio.grpc.CmdProgress
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- getJobProgressOrBuilderList() - Method in interface alluxio.grpc.CmdProgressOrBuilder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- GetJobProgressPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetJobProgressPRequest
- GetJobProgressPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetJobProgressPRequest
- GetJobProgressPRequestOrBuilder - Interface in alluxio.grpc
-
- GetJobProgressPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetJobProgressPResponse
- GetJobProgressPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetJobProgressPResponse
- GetJobProgressPResponseOrBuilder - Interface in alluxio.grpc
-
- getJobs() - Method in class alluxio.job.workflow.composite.CompositeConfig
-
- getJobs() - Method in class alluxio.master.scheduler.JournaledJobMetaStore
-
- getJobs() - Method in class alluxio.master.scheduler.Scheduler
-
Get jobs.
- getJobs() - Method in interface alluxio.scheduler.job.JobMetaStore
-
- getJobServiceSummary() - Method in interface alluxio.client.job.JobMasterClient
-
Gets the job service summary.
- getJobServiceSummary() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- getJobServiceSummary(GetJobServiceSummaryPRequest, StreamObserver<GetJobServiceSummaryPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
-
Gets the summary of the job service.
- getJobServiceSummary(GetJobServiceSummaryPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
-
Gets the summary of the job service.
- getJobServiceSummary(GetJobServiceSummaryPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
-
Gets the summary of the job service.
- getJobServiceSummary(GetJobServiceSummaryPRequest, StreamObserver<GetJobServiceSummaryPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
-
Gets the summary of the job service.
- getJobServiceSummary(GetJobServiceSummaryPRequest, StreamObserver<GetJobServiceSummaryPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
-
- GetJobServiceSummaryPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPOptions
- GetJobServiceSummaryPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPOptions
- GetJobServiceSummaryPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetJobServiceSummaryPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPRequest
- GetJobServiceSummaryPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPRequest
- GetJobServiceSummaryPRequestOrBuilder - Interface in alluxio.grpc
-
- GetJobServiceSummaryPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPResponse
- GetJobServiceSummaryPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPResponse
- GetJobServiceSummaryPResponseOrBuilder - Interface in alluxio.grpc
-
- getJobSource() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.JobSource jobSource = 3;
- getJobSource() - Method in class alluxio.grpc.CmdSummary
-
optional .alluxio.grpc.job.JobSource jobSource = 3;
- getJobSource() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional .alluxio.grpc.job.JobSource jobSource = 3;
- getJobSource() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
-
- getJobSource() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
-
- getJobSource() - Method in interface alluxio.job.CmdConfig
-
- getJobSource() - Method in class alluxio.master.job.common.CmdInfo
-
Get job source.
- getJobState() - Method in class alluxio.master.job.AbstractJob
-
Get load status.
- getJobState(JobDescription) - Method in class alluxio.master.scheduler.Scheduler
-
Get the job's state.
- getJobState() - Method in interface alluxio.scheduler.job.Job
-
- getJobStatus(long, AlluxioConfiguration, boolean) - Static method in class alluxio.client.job.JobGrpcClientUtils
-
- getJobStatus(long) - Method in interface alluxio.client.job.JobMasterClient
-
Gets the status of the given job id.
- getJobStatus(long) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- getJobStatus(GetJobStatusPRequest, StreamObserver<GetJobStatusPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
-
Gets the status of the given job.
- getJobStatus(GetJobStatusPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
-
Gets the status of the given job.
- getJobStatus(GetJobStatusPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
-
Gets the status of the given job.
- getJobStatus(GetJobStatusPRequest, StreamObserver<GetJobStatusPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
-
Gets the status of the given job.
- getJobStatus() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional .alluxio.grpc.job.Status jobStatus = 2;
- getJobStatus() - Method in class alluxio.grpc.JobStatusBlock
-
optional .alluxio.grpc.job.Status jobStatus = 2;
- getJobStatus() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
-
optional .alluxio.grpc.job.Status jobStatus = 2;
- getJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional .alluxio.grpc.job.Status job_status = 5;
- getJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional .alluxio.grpc.job.Status job_status = 5;
- getJobStatus() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional .alluxio.grpc.job.Status job_status = 5;
- getJobStatus(GetJobStatusPRequest, StreamObserver<GetJobStatusPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
-
- getJobStatusBlock(int) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlock(int) - Method in class alluxio.grpc.CmdStatusBlock
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlock(int) - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlock() - Method in class alluxio.job.wire.CmdStatusBlock
-
Get a list of job status block for a command.
- getJobStatusBlockBuilder(int) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockBuilderList() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockCount() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockCount() - Method in class alluxio.grpc.CmdStatusBlock
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockCount() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockList() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockList() - Method in class alluxio.grpc.CmdStatusBlock
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockList() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockOrBuilder(int) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockOrBuilder(int) - Method in class alluxio.grpc.CmdStatusBlock
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockOrBuilder(int) - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockOrBuilderList() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockOrBuilderList() - Method in class alluxio.grpc.CmdStatusBlock
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusBlockOrBuilderList() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- getJobStatusDetailed(long) - Method in interface alluxio.client.job.JobMasterClient
-
Gets detailed status of the given job id.
- getJobStatusDetailed(long) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- getJobStatusDetailed(GetJobStatusDetailedPRequest, StreamObserver<GetJobStatusDetailedPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
-
Gets the status of the given job.
- getJobStatusDetailed(GetJobStatusDetailedPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
-
Gets the status of the given job.
- getJobStatusDetailed(GetJobStatusDetailedPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
-
Gets the status of the given job.
- getJobStatusDetailed(GetJobStatusDetailedPRequest, StreamObserver<GetJobStatusDetailedPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
-
Gets the status of the given job.
- getJobStatusDetailed(GetJobStatusDetailedPRequest, StreamObserver<GetJobStatusDetailedPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
-
- GetJobStatusDetailedPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPOptions
- GetJobStatusDetailedPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPOptions
- GetJobStatusDetailedPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetJobStatusDetailedPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPRequest
- GetJobStatusDetailedPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPRequest
- GetJobStatusDetailedPRequestOrBuilder - Interface in alluxio.grpc
-
- GetJobStatusDetailedPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPResponse
- GetJobStatusDetailedPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPResponse
- GetJobStatusDetailedPResponseOrBuilder - Interface in alluxio.grpc
-
- GetJobStatusPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusPOptions
- GetJobStatusPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusPOptions
- GetJobStatusPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetJobStatusPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusPRequest
- GetJobStatusPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusPRequest
- GetJobStatusPRequestOrBuilder - Interface in alluxio.grpc
-
- GetJobStatusPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusPResponse
- GetJobStatusPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.GetJobStatusPResponse
- GetJobStatusPResponseOrBuilder - Interface in alluxio.grpc
-
- getJobStopped() - Method in class alluxio.grpc.StopJobPResponse.Builder
-
optional bool jobStopped = 1;
- getJobStopped() - Method in class alluxio.grpc.StopJobPResponse
-
optional bool jobStopped = 1;
- getJobStopped() - Method in interface alluxio.grpc.StopJobPResponseOrBuilder
-
optional bool jobStopped = 1;
- getJobSubmissionTime() - Method in class alluxio.master.job.common.CmdInfo
-
Get submission time.
- getJobTaskArgs() - Method in class alluxio.job.plan.batch.BatchedJobDefinition.BatchedJobTask
-
- getJobType() - Method in class alluxio.job.plan.BatchedJobConfig
-
- getJobWorkerHealth() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- getJobWorkerHealth() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- getJobWorkerHealth() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- getJobWorkerHealthBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- getJobWorkerHealthOrBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- getJobWorkerHealthOrBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- getJobWorkerHealthOrBuilder() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- getJobWorkerHealthReport() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter
-
- getJobWorkerMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
-
Builds metric registry name for job worker instance.
- getJournal(URI) - Method in class alluxio.underfs.AbstractUfsManager
-
- getJournal(URI) - Method in interface alluxio.underfs.UfsManager
-
- getJournalCheckpointTimeWarning() - Method in class alluxio.wire.MasterWebUIOverview
-
- getJournalContext() - Method in class alluxio.master.file.RpcContext
-
- getJournalDir() - Method in class alluxio.multi.process.MultiProcessCluster
-
- getJournalDir(int) - Method in class alluxio.multi.process.MultiProcessCluster
-
- getJournalDiskMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
-
- getJournalDiskWarnings() - Method in class alluxio.master.meta.JournalSpaceMonitor
-
- getJournalDiskWarnings() - Method in class alluxio.wire.MasterWebUIOverview
-
- getJournaled() - Method in class alluxio.master.journal.JournaledGroup
-
- getJournaledNextContainerId() - Method in interface alluxio.master.block.BlockMaster
-
Returns the internal JournaledNextContainerId.
- getJournaledNextContainerId() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getJournalEntries(int) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
This journal entry is a list of other entries.
- getJournalEntries(int) - Method in class alluxio.proto.journal.Journal.JournalEntry
-
This journal entry is a list of other entries.
- getJournalEntries(int) - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
This journal entry is a list of other entries.
- getJournalEntriesBuilder(int) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
This journal entry is a list of other entries.
- getJournalEntriesBuilderList() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
This journal entry is a list of other entries.
- getJournalEntriesCount() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
This journal entry is a list of other entries.
- getJournalEntriesCount() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
This journal entry is a list of other entries.
- getJournalEntriesCount() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
This journal entry is a list of other entries.
- getJournalEntriesList() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
This journal entry is a list of other entries.
- getJournalEntriesList() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
This journal entry is a list of other entries.
- getJournalEntriesList() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
This journal entry is a list of other entries.
- getJournalEntriesOrBuilder(int) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
This journal entry is a list of other entries.
- getJournalEntriesOrBuilder(int) - Method in class alluxio.proto.journal.Journal.JournalEntry
-
This journal entry is a list of other entries.
- getJournalEntriesOrBuilder(int) - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
This journal entry is a list of other entries.
- getJournalEntriesOrBuilderList() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
This journal entry is a list of other entries.
- getJournalEntriesOrBuilderList() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
This journal entry is a list of other entries.
- getJournalEntriesOrBuilderList() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
This journal entry is a list of other entries.
- getJournalEntriesSinceCheckpoint() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
optional int64 journalEntriesSinceCheckpoint = 2;
- getJournalEntriesSinceCheckpoint() - Method in class alluxio.grpc.MasterHeartbeatPOptions
-
optional int64 journalEntriesSinceCheckpoint = 2;
- getJournalEntriesSinceCheckpoint() - Method in interface alluxio.grpc.MasterHeartbeatPOptionsOrBuilder
-
optional int64 journalEntriesSinceCheckpoint = 2;
- getJournalEntriesSinceCheckpoint() - Method in class alluxio.master.meta.MasterInfo
-
- getJournalEntriesSinceCheckpoint() - Method in class alluxio.wire.MasterInfo
-
- getJournalEntriesSinceCheckpoint() - Method in class alluxio.wire.MasterWebUIMetrics
-
- getJournalEntryIterator() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getJournalEntryIterator() - Method in class alluxio.master.file.meta.InodeDirectoryIdGenerator
-
- getJournalEntryIterator() - Method in class alluxio.master.file.meta.InodeTreePersistentState
-
- getJournalEntryIterator() - Method in class alluxio.master.file.meta.MountTable.State
-
- getJournalEntryIterator() - Method in interface alluxio.master.journal.DelegatingJournaled
-
- getJournalEntryIterator() - Method in class alluxio.master.journal.JournaledGroup
-
- getJournalEntryIterator() - Method in interface alluxio.master.journal.JournalEntryIterable
-
- getJournalEntryIterator() - Method in interface alluxio.master.journal.NoopJournaled
-
- getJournalEntryIterator() - Method in class alluxio.master.journal.SingleEntryJournaled
-
- getJournalEntryIterator() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getJournalEntryIterator() - Method in class alluxio.master.meta.DefaultMetaMaster.State
-
- getJournalEntryIterator() - Method in class alluxio.master.meta.PathProperties.State
-
- getJournalEntryIterator() - Method in class alluxio.master.scheduler.JournaledJobMetaStore
-
- getJournalEntryIterator() - Method in class alluxio.underfs.MasterUfsManager
-
- getJournalFolder() - Method in class alluxio.master.LocalAlluxioMaster
-
- getJournalFormatter() - Method in class alluxio.master.journalv0.ufs.UfsJournal
-
- getJournalLastCheckpointTime() - Method in class alluxio.wire.MasterWebUIMetrics
-
- getJournalLocation() - Static method in class alluxio.master.journal.JournalUtils
-
Returns a URI for the configured location for the specified journal.
- getJournalMasterClientForJobMaster() - Method in class alluxio.cli.fsadmin.command.Context
-
- getJournalMasterClientForMaster() - Method in class alluxio.cli.fsadmin.command.Context
-
- getJournalMasterClientForMaster() - Method in class alluxio.multi.process.MultiProcessCluster
-
- getJournalName() - Method in class alluxio.master.journal.AbstractJournalProgressLogger
-
- getJournalName() - Method in class alluxio.master.journal.raft.RaftJournalProgressLogger
-
- getJournalName() - Method in class alluxio.master.journal.ufs.UfsJournalProgressLogger
-
- getJournalSequences() - Method in class alluxio.master.backup.BackupRequestMessage
-
- getJournalServices() - Method in interface alluxio.master.journal.JournalSystem
-
- getJournalServices() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- getJournalSinks(Master) - Method in class alluxio.master.journal.AbstractJournalSystem
-
- getJournalSinks(Master) - Method in interface alluxio.master.journal.JournalSystem
-
- getJournalSinks(Master) - Method in class alluxio.master.journal.noop.NoopJournalSystem
-
- getJournalSpaceMonitor() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getJournalSpaceMonitor() - Method in interface alluxio.master.meta.MetaMaster
-
- getJournalSystem() - Method in class alluxio.master.CoreMasterContext
-
- getJournalSystem() - Method in class alluxio.master.MasterContext
-
- getJournalUfsConf() - Static method in class alluxio.master.journal.ufs.UfsJournal
-
- getKeepAliveClient() - Method in class alluxio.membership.DefaultServiceEntity
-
Get the keepalive client instance.
- getKey() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- getKey() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- getKey() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- getKey() - Method in class alluxio.master.meta.checkconf.ConfigRecord
-
- getKey() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string key = 1;
- getKey() - Method in class alluxio.proto.journal.File.StringPairEntry
-
optional string key = 1;
- getKey() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
-
optional string key = 1;
- getKey() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- getKey() - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
-
- getKey() - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
-
- getKey() - Method in class alluxio.proxy.s3.ListPartsResult
-
- getKey() - Method in class alluxio.s3.DeleteObjectsRequest.DeleteObject
-
- getKey() - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
-
- getKey() - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
-
- getKey() - Method in class alluxio.s3.ListBucketResult.Content
-
- getKeyBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- getKeyBytes() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string key = 1;
- getKeyBytes() - Method in class alluxio.proto.journal.File.StringPairEntry
-
optional string key = 1;
- getKeyBytes() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
-
optional string key = 1;
- getKeyCount() - Method in class alluxio.s3.ListBucketResult
-
- getKeyFromPageId(PageId) - Method in class alluxio.client.file.cache.store.MemoryPageStore
-
- getKeyOrBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- getKeyOrBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- getKeyOrBuilder() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- getKeys(int) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
repeated string keys = 2;
- getKeys(int) - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
repeated string keys = 2;
- getKeys(int) - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
-
repeated string keys = 2;
- getKeysBytes(int) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
repeated string keys = 2;
- getKeysBytes(int) - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
repeated string keys = 2;
- getKeysBytes(int) - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
-
repeated string keys = 2;
- getKeysCount() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
repeated string keys = 2;
- getKeysCount() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
repeated string keys = 2;
- getKeysCount() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
-
repeated string keys = 2;
- getKeysList() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
repeated string keys = 2;
- getKeysList() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
repeated string keys = 2;
- getKeysList() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
-
repeated string keys = 2;
- getLastAccessedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 last_accessed_ms = 30;
- getLastAccessedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 last_accessed_ms = 30;
- getLastAccessedMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 last_accessed_ms = 30;
- getLastAccessTimeMs() - Method in class alluxio.client.file.URIStatus
-
- getLastAccessTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 lastAccessTimeMs = 31;
- getLastAccessTimeMs() - Method in class alluxio.grpc.FileInfo
-
optional int64 lastAccessTimeMs = 31;
- getLastAccessTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 lastAccessTimeMs = 31;
- getLastAccessTimeMs() - Method in class alluxio.master.file.meta.Inode
-
- getLastAccessTimeMs() - Method in interface alluxio.master.file.meta.InodeView
-
- getLastAccessTimeMs() - Method in class alluxio.master.file.meta.MutableInode
-
- getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 last_access_time_ms = 20;
- getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 last_access_time_ms = 20;
- getLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 last_access_time_ms = 20;
- getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 last_access_time_ms = 29;
- getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 last_access_time_ms = 29;
- getLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 last_access_time_ms = 29;
- getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 last_access_time_ms = 18;
- getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 last_access_time_ms = 18;
- getLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 last_access_time_ms = 18;
- getLastAccessTimeMs() - Method in class alluxio.resource.DynamicResourcePool.ResourceInternal
-
- getLastAccessTimeMs() - Method in class alluxio.util.webui.UIFileBlockInfo
-
Gets last access time ms.
- getLastAccessTimeMs() - Method in class alluxio.wire.FileInfo
-
- getLastAccessTimeMs() - Method in class alluxio.worker.dora.OpenFileHandle
-
Get last accessed time.
- getLastAppliedCommitIndex() - Method in class alluxio.master.journal.raft.JournalStateMachine
-
- getLastAppliedIndex() - Method in class alluxio.master.journal.AbstractJournalProgressLogger
-
- getLastAppliedIndex() - Method in class alluxio.master.journal.raft.RaftJournalProgressLogger
-
- getLastAppliedIndex() - Method in class alluxio.master.journal.ufs.UfsJournalProgressLogger
-
- getLastAppliedSequenceNumber() - Method in class alluxio.master.journal.raft.JournalStateMachine
-
- getLastCheckpointTime() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
optional int64 lastCheckpointTime = 1;
- getLastCheckpointTime() - Method in class alluxio.grpc.MasterHeartbeatPOptions
-
optional int64 lastCheckpointTime = 1;
- getLastCheckpointTime() - Method in interface alluxio.grpc.MasterHeartbeatPOptionsOrBuilder
-
optional int64 lastCheckpointTime = 1;
- getLastCheckpointTime() - Method in class alluxio.wire.MasterInfo
-
- getLastCheckpointTimeMs() - Method in class alluxio.master.meta.MasterInfo
-
- getLastClearTime() - Method in class alluxio.master.metrics.MetricsStore
-
- getLastComputed() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter.JobWorkerHealthReport
-
Returns the worker health observed time.
- getLastContactSec() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int32 lastContactSec = 3;
- getLastContactSec() - Method in class alluxio.grpc.WorkerInfo
-
optional int32 lastContactSec = 3;
- getLastContactSec() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional int32 lastContactSec = 3;
- getLastContactSec() - Method in class alluxio.wire.WorkerInfo
-
- getLastExistingInode() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getLastHeartbeat() - Method in class alluxio.util.webui.NodeInfo
-
Gets last heartbeat.
- getLastHeartbeatTime() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional int64 lastHeartbeatTime = 4;
- getLastHeartbeatTime() - Method in class alluxio.grpc.ProxyStatus
-
optional int64 lastHeartbeatTime = 4;
- getLastHeartbeatTime() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional int64 lastHeartbeatTime = 4;
- getLastHeartbeatTimeMs() - Method in class alluxio.master.meta.ProxyInfo
-
- getLastItem() - Method in class alluxio.underfs.UfsLoadResult
-
- getLastModificationTimeMs() - Method in class alluxio.client.file.URIStatus
-
- getLastModificationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 lastModificationTimeMs = 14;
- getLastModificationTimeMs() - Method in class alluxio.grpc.FileInfo
-
optional int64 lastModificationTimeMs = 14;
- getLastModificationTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 lastModificationTimeMs = 14;
- getLastModificationTimeMs() - Method in class alluxio.master.file.meta.Inode
-
- getLastModificationTimeMs() - Method in interface alluxio.master.file.meta.InodeView
-
- getLastModificationTimeMs() - Method in class alluxio.master.file.meta.MutableInode
-
- getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 last_modification_time_ms = 7;
- getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 last_modification_time_ms = 7;
- getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 last_modification_time_ms = 7;
- getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 last_modification_time_ms = 7;
- getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
optional int64 last_modification_time_ms = 2;
- getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
optional int64 last_modification_time_ms = 2;
- getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
-
optional int64 last_modification_time_ms = 2;
- getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 last_modification_time_ms = 7;
- getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 last_modification_time_ms = 7;
- getLastModificationTimeMs() - Method in class alluxio.wire.FileInfo
-
- getLastModified() - Method in class alluxio.proxy.s3.ListPartsResult.Part
-
- getLastModified() - Method in class alluxio.s3.CopyObjectResult
-
- getLastModified() - Method in class alluxio.s3.ListBucketResult.Content
-
- getLastModifiedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 last_modified_ms = 25;
- getLastModifiedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 last_modified_ms = 25;
- getLastModifiedMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 last_modified_ms = 25;
- getLastModifiedTime() - Method in class alluxio.underfs.UfsStatus
-
Gets the UTC time of when the indicated path was modified recently in ms, or null if the last
modified time is not available.
- getLastModifiedTimeMs() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional int64 last_modified_time_ms = 3;
- getLastModifiedTimeMs() - Method in class alluxio.grpc.UfsStatus
-
optional int64 last_modified_time_ms = 3;
- getLastModifiedTimeMs() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional int64 last_modified_time_ms = 3;
- getLastModifiedTimeMs() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
-
Gets the last modified epoch time in ms.
- getLastPrimaryStartSequenceNumber() - Method in class alluxio.master.journal.raft.JournalStateMachine
-
- getLastSN(UfsJournal) - Static method in class alluxio.master.journal.ufs.UfsJournalReader
-
Iterates over the journal files searching for the greatest SN of all the files.
- getLastStatusChangeMs() - Method in class alluxio.job.plan.meta.PlanInfo
-
- getLastSyncTime() - Method in class alluxio.master.file.meta.SyncCheck
-
- getLastSyncTime() - Method in class alluxio.master.file.meta.SyncCheck.SyncResult
-
- getLastUpdated() - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 lastUpdated = 6;
- getLastUpdated() - Method in class alluxio.grpc.JobInfo
-
optional int64 lastUpdated = 6;
- getLastUpdated() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional int64 lastUpdated = 6;
- getLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int64 lastUpdated = 3;
- getLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth
-
optional int64 lastUpdated = 3;
- getLastUpdated() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional int64 lastUpdated = 3;
- getLastUpdated() - Method in interface alluxio.job.wire.JobInfo
-
- getLastUpdated() - Method in class alluxio.job.wire.PlanInfo
-
- getLastUpdated() - Method in class alluxio.job.wire.TaskInfo
-
- getLastUpdated() - Method in class alluxio.job.wire.WorkflowInfo
-
- getLastUpdated() - Method in class alluxio.job.workflow.WorkflowExecution
-
- getLastUpdatedTime() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional int64 lastUpdatedTime = 5;
- getLastUpdatedTime() - Method in class alluxio.grpc.ActionInfo
-
optional int64 lastUpdatedTime = 5;
- getLastUpdatedTime() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional int64 lastUpdatedTime = 5;
- getLastUpdatedTime() - Method in class alluxio.util.webui.UIMasterInfo
-
Get master last update time.
- getLastUpdatedTime() - Method in class alluxio.wire.MasterInfo
-
- getLastUpdatedTimeMs() - Method in class alluxio.job.MasterWorkerInfo
-
- getLastUpdatedTimeMs() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
No locking required.
- getLastUpdatedTimeMs() - Method in class alluxio.master.meta.JobMasterInfo
-
- getLastUpdatedTimeMs() - Method in class alluxio.master.meta.MasterInfo
-
- getLastUpdateMs() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 lastUpdateMs = 4;
- getLastUpdateMs() - Method in class alluxio.grpc.JobProgress
-
optional int64 lastUpdateMs = 4;
- getLastUpdateMs() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional int64 lastUpdateMs = 4;
- getLastUpdateTime() - Method in class alluxio.conf.AlluxioProperties
-
- getLastUpdateTime() - Static method in class alluxio.conf.Configuration
-
- getLastUpdateTime() - Method in class alluxio.conf.Hash
-
- getLastUpdateTime() - Method in class alluxio.conf.InstancedConfiguration
-
- getLastUpdateTime() - Method in class alluxio.master.meta.PathProperties
-
- getLastUpdateTime() - Method in class alluxio.master.meta.PathPropertiesView
-
- getLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- getLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse
-
Deprecated.
- getLatest() - Method in interface alluxio.grpc.GetSnapshotInfoResponseOrBuilder
-
Deprecated.
- getLatestBuilder() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- getLatestCheckpoint() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
-
- getLatestContent() - Method in class alluxio.worker.s3.S3NettyHandler
-
get HTTP content of this request.
- getLatestOrBuilder() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- getLatestOrBuilder() - Method in class alluxio.grpc.GetSnapshotInfoResponse
-
Deprecated.
- getLatestOrBuilder() - Method in interface alluxio.grpc.GetSnapshotInfoResponseOrBuilder
-
Deprecated.
- getLatestSequenceNumber() - Method in interface alluxio.master.journalv0.JournalInputStream
-
- getLatestSnapshot() - Method in class alluxio.master.journal.raft.JournalStateMachine
-
- getLatestSnapshot() - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
-
- getLatestVersion(String, List<String>, long, long, long) - Static method in class alluxio.check.UpdateCheck
-
- getLayout() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Layout layout = 6;
- getLayout() - Method in class alluxio.grpc.table.TableInfo
-
optional .alluxio.grpc.table.Layout layout = 6;
- getLayout() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional .alluxio.grpc.table.Layout layout = 6;
- getLayout() - Method in class alluxio.grpc.table.Transformation.Builder
-
optional .alluxio.grpc.table.Layout layout = 1;
- getLayout() - Method in class alluxio.grpc.table.Transformation
-
optional .alluxio.grpc.table.Layout layout = 1;
- getLayout() - Method in interface alluxio.grpc.table.TransformationOrBuilder
-
optional .alluxio.grpc.table.Layout layout = 1;
- getLayoutBuilder() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Layout layout = 6;
- getLayoutBuilder() - Method in class alluxio.grpc.table.Transformation.Builder
-
optional .alluxio.grpc.table.Layout layout = 1;
- getLayoutData() - Method in class alluxio.grpc.table.Layout.Builder
-
optional bytes layout_data = 3;
- getLayoutData() - Method in class alluxio.grpc.table.Layout
-
optional bytes layout_data = 3;
- getLayoutData() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
optional bytes layout_data = 3;
- getLayoutOrBuilder() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Layout layout = 6;
- getLayoutOrBuilder() - Method in class alluxio.grpc.table.TableInfo
-
optional .alluxio.grpc.table.Layout layout = 6;
- getLayoutOrBuilder() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional .alluxio.grpc.table.Layout layout = 6;
- getLayoutOrBuilder() - Method in class alluxio.grpc.table.Transformation.Builder
-
optional .alluxio.grpc.table.Layout layout = 1;
- getLayoutOrBuilder() - Method in class alluxio.grpc.table.Transformation
-
optional .alluxio.grpc.table.Layout layout = 1;
- getLayoutOrBuilder() - Method in interface alluxio.grpc.table.TransformationOrBuilder
-
optional .alluxio.grpc.table.Layout layout = 1;
- getLayoutSpec() - Method in class alluxio.grpc.table.Layout.Builder
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- getLayoutSpec() - Method in class alluxio.grpc.table.Layout
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- getLayoutSpec() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- getLayoutSpecBuilder() - Method in class alluxio.grpc.table.Layout.Builder
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- getLayoutSpecOrBuilder() - Method in class alluxio.grpc.table.Layout.Builder
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- getLayoutSpecOrBuilder() - Method in class alluxio.grpc.table.Layout
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- getLayoutSpecOrBuilder() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- getLayoutType() - Method in class alluxio.grpc.table.Layout.Builder
-
optional string layout_type = 1;
- getLayoutType() - Method in class alluxio.grpc.table.Layout
-
optional string layout_type = 1;
- getLayoutType() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
optional string layout_type = 1;
- getLayoutTypeBytes() - Method in class alluxio.grpc.table.Layout.Builder
-
optional string layout_type = 1;
- getLayoutTypeBytes() - Method in class alluxio.grpc.table.Layout
-
optional string layout_type = 1;
- getLayoutTypeBytes() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
optional string layout_type = 1;
- getLeaderId() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
Get the leader id.
- getLeaderId() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets leader id.
- getLeaderIndex() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
Gets leader index.
- getLeaderIndex() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- getLeaderIndex() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- getLeaderMasterAddress() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string leaderMasterAddress = 1;
- getLeaderMasterAddress() - Method in class alluxio.grpc.MasterInfo
-
optional string leaderMasterAddress = 1;
- getLeaderMasterAddress() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional string leaderMasterAddress = 1;
- getLeaderMasterAddressBytes() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string leaderMasterAddress = 1;
- getLeaderMasterAddressBytes() - Method in class alluxio.grpc.MasterInfo
-
optional string leaderMasterAddress = 1;
- getLeaderMasterAddressBytes() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional string leaderMasterAddress = 1;
- getLeaderPath() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
-
- getLeadingPath(int) - Method in class alluxio.AlluxioURI
-
Gets the first n components of the
AlluxioURI
path.
- getLease() - Method in class alluxio.membership.DefaultServiceEntity
-
- getLeaseTimeoutInSec() - Method in class alluxio.membership.DefaultServiceEntity
-
Get the timeout for lease in seconds.
- getLeaseTTLInSec() - Method in class alluxio.membership.DefaultServiceEntity
-
Get the TTL for lease in seconds.
- getLeastSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
-
optional int64 leastSignificantBits = 2;
- getLeastSignificantBits() - Method in class alluxio.grpc.FsOpPId
-
optional int64 leastSignificantBits = 2;
- getLeastSignificantBits() - Method in interface alluxio.grpc.FsOpPIdOrBuilder
-
optional int64 leastSignificantBits = 2;
- getLeastSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
optional int64 leastSignificantBits = 2;
- getLeastSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId
-
optional int64 leastSignificantBits = 2;
- getLeastSignificantBits() - Method in interface alluxio.proto.journal.Journal.JournalOpPIdOrBuilder
-
optional int64 leastSignificantBits = 2;
- getLength() - Method in class alluxio.client.file.URIStatus
-
- getLength() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int64 length = 5;
- getLength() - Method in class alluxio.grpc.AsyncCacheRequest
-
optional int64 length = 5;
- getLength() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
optional int64 length = 5;
- getLength() - Method in class alluxio.grpc.Block.Builder
-
The block length.
- getLength() - Method in class alluxio.grpc.Block
-
The block length.
- getLength() - Method in class alluxio.grpc.BlockInfo.Builder
-
optional int64 length = 2;
- getLength() - Method in class alluxio.grpc.BlockInfo
-
optional int64 length = 2;
- getLength() - Method in interface alluxio.grpc.BlockInfoOrBuilder
-
optional int64 length = 2;
- getLength() - Method in interface alluxio.grpc.BlockOrBuilder
-
The block length.
- getLength() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int64 length = 5;
- getLength() - Method in class alluxio.grpc.CacheRequest
-
optional int64 length = 5;
- getLength() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional int64 length = 5;
- getLength() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the length of the block being committed
- getLength() - Method in class alluxio.grpc.CommitBlockPRequest
-
the length of the block being committed
- getLength() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the length of the block being committed
- getLength() - Method in class alluxio.grpc.File.Builder
-
file length
- getLength() - Method in class alluxio.grpc.File
-
file length
- getLength() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 length = 5;
- getLength() - Method in class alluxio.grpc.FileInfo
-
optional int64 length = 5;
- getLength() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 length = 5;
- getLength() - Method in interface alluxio.grpc.FileOrBuilder
-
file length
- getLength() - Method in class alluxio.grpc.ReadableDataBuffer
-
- getLength() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 length = 3;
- getLength() - Method in class alluxio.grpc.ReadRequest
-
optional int64 length = 3;
- getLength() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
optional int64 length = 3;
- getLength() - Method in class alluxio.grpc.Route.Builder
-
optional int64 length = 3;
- getLength() - Method in class alluxio.grpc.Route
-
optional int64 length = 3;
- getLength() - Method in interface alluxio.grpc.RouteOrBuilder
-
optional int64 length = 3;
- getLength() - Method in class alluxio.master.file.meta.InodeFile
-
- getLength() - Method in interface alluxio.master.file.meta.InodeFileView
-
- getLength() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getLength() - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
-
- getLength() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
-
Returns the length of the data.
- getLength() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
-
- getLength() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
-
- getLength() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
-
- getLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int64 length = 5;
- getLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
optional int64 length = 5;
- getLength() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
optional int64 length = 5;
- getLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 length = 3;
- getLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
optional int64 length = 3;
- getLength() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
optional int64 length = 3;
- getLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional int64 length = 2;
- getLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
optional int64 length = 2;
- getLength() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
-
optional int64 length = 2;
- getLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 length = 3;
- getLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
optional int64 length = 3;
- getLength() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
optional int64 length = 3;
- getLength() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 length = 9;
- getLength() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 length = 9;
- getLength() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 length = 9;
- getLength() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 length = 2;
- getLength() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
optional int64 length = 2;
- getLength() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
-
optional int64 length = 2;
- getLength() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 length = 3;
- getLength() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int64 length = 3;
- getLength() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int64 length = 3;
- getLength() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
optional int64 length = 1;
- getLength() - Method in class alluxio.proto.meta.Block.BlockMeta
-
optional int64 length = 1;
- getLength() - Method in interface alluxio.proto.meta.Block.BlockMetaOrBuilder
-
optional int64 length = 1;
- getLength() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 length = 19;
- getLength() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 length = 19;
- getLength() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 length = 19;
- getLength(long) - Method in class alluxio.s3.S3RangeSpec
-
Get real length of object.
- getLength() - Method in class alluxio.underfs.options.OpenOptions
-
- getLength() - Method in class alluxio.wire.BlockInfo
-
- getLength() - Method in class alluxio.wire.FileInfo
-
- getLength() - Method in class alluxio.worker.block.io.BlockReader
-
Gets the length of the block in bytes.
- getLength() - Method in class alluxio.worker.dora.PagedFileReader
-
- getLength() - Method in class alluxio.worker.http.ResponseFileInfo
-
Get the length of the file.
- getLevel() - Method in class alluxio.wire.LogInfo
-
- getLFULogBase() - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
-
- getLibfuseVersion(AlluxioConfiguration) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Gets the libjnifuse version preference set by user.
- getList() - Method in class alluxio.collections.PrefixList
-
Gets the list of prefixes.
- getList(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the value for the given key as a list.
- getList(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the value for the given key as a list.
- getList(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getList(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getListAllMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getListingChunkLength(AlluxioConfiguration) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
The number of items to query in a single listing chunk.
- getListingChunkLengthMax() - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Maximum number of items in a single listing chunk supported by the under store.
- getListings() - Method in class alluxio.client.file.ListStatusPartialResult
-
- getListPolicyMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
-
- getListProxyStatusMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
-
- getListStatusMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getListStatusMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getListStatusPartialMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getListType() - Method in class alluxio.s3.ListBucketOptions
-
- getLiveMembers() - Method in class alluxio.membership.EtcdMembershipManager
-
- getLiveMembers() - Method in class alluxio.membership.MasterMembershipManager
-
- getLiveMembers() - Method in interface alluxio.membership.MembershipManager
-
Get healthy workers.
- getLiveMembers() - Method in class alluxio.membership.StaticMembershipManager
-
- getLiveNodeAddresses() - Method in class alluxio.master.meta.checkconf.ConfigurationStore
-
- getLiveWorkerInfos() - Method in class alluxio.master.scheduler.DefaultWorkerProvider
-
- getLiveWorkerInfos() - Method in class alluxio.master.scheduler.MembershipManagerWorkerProvider
-
- getLiveWorkerInfos() - Method in interface alluxio.master.scheduler.WorkerProvider
-
Get live workerInfo list.
- getLiveWorkerNodes() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets live worker nodes.
- getLiveWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 liveWorkerNum = 4;
- getLiveWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int32 liveWorkerNum = 4;
- getLiveWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int32 liveWorkerNum = 4;
- getLiveWorkerNum() - Method in class alluxio.wire.BlockMasterInfo
-
- getLiveWorkers() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get live workers.
- getLiveWorkers() - Method in class alluxio.client.file.FileSystemContext
-
Gets the live worker information list.
- getLoadAverage(int) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
repeated double loadAverage = 2;
- getLoadAverage(int) - Method in class alluxio.grpc.JobWorkerHealth
-
repeated double loadAverage = 2;
- getLoadAverage(int) - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
repeated double loadAverage = 2;
- getLoadAverage() - Method in class alluxio.job.wire.JobWorkerHealth
-
Returns system load average for 1, 5, and 15 minutes.
- getLoadAverageCount() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
repeated double loadAverage = 2;
- getLoadAverageCount() - Method in class alluxio.grpc.JobWorkerHealth
-
repeated double loadAverage = 2;
- getLoadAverageCount() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
repeated double loadAverage = 2;
- getLoadAverageList() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
repeated double loadAverage = 2;
- getLoadAverageList() - Method in class alluxio.grpc.JobWorkerHealth
-
repeated double loadAverage = 2;
- getLoadAverageList() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
repeated double loadAverage = 2;
- getLoadDescendantType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
- getLoadDescendantType() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
- getLoadDescendantType() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
- getLoadDirectChildren() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
This is deprecated since 1.1.1 and will be removed in 2.0.
- getLoadDirectChildren() - Method in class alluxio.grpc.ListStatusPOptions
-
This is deprecated since 1.1.1 and will be removed in 2.0.
- getLoadDirectChildren() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
This is deprecated since 1.1.1 and will be removed in 2.0.
- getLoadFileMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getLoadJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- getLoadJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- getLoadJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- getLoadJobBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- getLoadJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- getLoadJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- getLoadJobOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- getLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
No data will be transferred.
- getLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions
-
No data will be transferred.
- getLoadMetadataOnly() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
No data will be transferred.
- getLoadMetadataOnly() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
If set false, only the metadata of file will be loaded.
- getLoadMetadataOnly() - Method in class alluxio.grpc.LoadFileRequest
-
If set false, only the metadata of file will be loaded.
- getLoadMetadataOnly() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
If set false, only the metadata of file will be loaded.
- getLoadMetadataOnly() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool loadMetadataOnly = 4;
- getLoadMetadataOnly() - Method in class alluxio.grpc.LoadJobPOptions
-
optional bool loadMetadataOnly = 4;
- getLoadMetadataOnly() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
-
optional bool loadMetadataOnly = 4;
- getLoadMetadataOnly() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional bool load_metadata_only = 9;
- getLoadMetadataOnly() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional bool load_metadata_only = 9;
- getLoadMetadataOnly() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional bool load_metadata_only = 9;
- getLoadMetadataType() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- getLoadMetadataType() - Method in class alluxio.grpc.ExistsPOptions
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- getLoadMetadataType() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- getLoadMetadataType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- getLoadMetadataType() - Method in class alluxio.grpc.GetStatusPOptions
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- getLoadMetadataType() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- getLoadMetadataType() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
- getLoadMetadataType() - Method in class alluxio.grpc.ListStatusPOptions
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
- getLoadMetadataType() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
- getLoadMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getLoadPath() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string load_path = 1;
- getLoadPath() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required string load_path = 1;
- getLoadPath() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required string load_path = 1;
- getLoadPathBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string load_path = 1;
- getLoadPathBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required string load_path = 1;
- getLoadPathBytes() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required string load_path = 1;
- getLoadState() - Static method in class alluxio.jnifuse.utils.NativeLibraryLoader
-
- getLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
- getLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
- getLoadType() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
- getLocalAlluxioMaster() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
- getLocalAlluxioMaster() - Method in class alluxio.master.LocalAlluxioCluster
-
- getLocalAlluxioMaster() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- getLocalAlluxioMaster() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- getLocalAlluxioMasterByIndex(int) - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- getLocalCacheDir() - Method in class alluxio.client.file.cache.PageInfo
-
- getLocalFileMode(String) - Static method in class alluxio.util.io.FileUtils
-
Gets local file's permission mode.
- getLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool localFileSystem = 1;
- getLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions
-
optional bool localFileSystem = 1;
- getLocalFileSystem() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
-
optional bool localFileSystem = 1;
- getLocalHostMetricName(int) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Gets a local hostname for the host this JVM is running on with '.' replaced with '_' for
metrics usage.
- getLocalHostName(int) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Gets a local host name for the host this JVM is running on.
- getLocalIpAddress(int) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Gets a local IP address for the host this JVM is running on.
- getLocalPeerId() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- getLocalPort() - Method in class alluxio.web.WebServer
-
Gets the actual port that the web server is listening on.
- getLocation() - Method in class alluxio.grpc.table.Database.Builder
-
optional string location = 3;
- getLocation() - Method in class alluxio.grpc.table.Database
-
optional string location = 3;
- getLocation() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string location = 3;
- getLocation() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional string location = 2;
- getLocation() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional string location = 2;
- getLocation() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional string location = 2;
- getLocation() - Method in interface alluxio.master.journal.Journal
-
- getLocation() - Method in class alluxio.master.journal.noop.NoopJournal
-
- getLocation() - Method in class alluxio.master.journal.raft.RaftJournal
-
- getLocation() - Method in class alluxio.master.journal.ufs.UfsJournal
-
- getLocation() - Method in class alluxio.master.journal.ufs.UfsJournalFile
-
- getLocation() - Method in interface alluxio.master.journalv0.Journal
-
- getLocation() - Method in class alluxio.master.journalv0.ufs.UfsJournal
-
- getLocation() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- getLocation() - Method in class alluxio.worker.block.AllocateOptions
-
- getLocation() - Method in class alluxio.worker.block.io.BlockReader
-
- getLocation() - Method in class alluxio.worker.dora.PagedFileReader
-
- getLocationBytes() - Method in class alluxio.grpc.table.Database.Builder
-
optional string location = 3;
- getLocationBytes() - Method in class alluxio.grpc.table.Database
-
optional string location = 3;
- getLocationBytes() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string location = 3;
- getLocationBytes() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional string location = 2;
- getLocationBytes() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional string location = 2;
- getLocationBytes() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional string location = 2;
- getLocationInternal(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
-
- getLocations(int) - Method in class alluxio.grpc.BlockInfo.Builder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocations(int) - Method in class alluxio.grpc.BlockInfo
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocations(int) - Method in interface alluxio.grpc.BlockInfoOrBuilder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocations(long) - Method in interface alluxio.master.metastore.BlockMetaStore
-
Gets locations for a block.
- getLocations(long) - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
-
- getLocations(long) - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
-
- getLocations() - Method in class alluxio.util.webui.UIFileBlockInfo
-
Gets locations.
- getLocations() - Method in class alluxio.wire.BlockInfo
-
- getLocations() - Method in class alluxio.wire.BlockLocationInfo
-
- getLocationsBuilder(int) - Method in class alluxio.grpc.BlockInfo.Builder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsBuilderList() - Method in class alluxio.grpc.BlockInfo.Builder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsCount() - Method in class alluxio.grpc.BlockInfo.Builder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsCount() - Method in class alluxio.grpc.BlockInfo
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsCount() - Method in interface alluxio.grpc.BlockInfoOrBuilder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsList() - Method in class alluxio.grpc.BlockInfo.Builder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsList() - Method in class alluxio.grpc.BlockInfo
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsList() - Method in interface alluxio.grpc.BlockInfoOrBuilder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsOrBuilder(int) - Method in class alluxio.grpc.BlockInfo.Builder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsOrBuilder(int) - Method in class alluxio.grpc.BlockInfo
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsOrBuilder(int) - Method in interface alluxio.grpc.BlockInfoOrBuilder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsOrBuilderList() - Method in class alluxio.grpc.BlockInfo.Builder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsOrBuilderList() - Method in class alluxio.grpc.BlockInfo
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLocationsOrBuilderList() - Method in interface alluxio.grpc.BlockInfoOrBuilder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- getLock() - Method in class alluxio.client.file.cache.DefaultPageMetaStore
-
- getLock() - Method in interface alluxio.client.file.cache.PageMetaStore
-
- getLockedInodes() - Method in class alluxio.master.file.meta.CompositeInodeLockList
-
- getLockedInodes() - Method in interface alluxio.master.file.meta.InodeLockList
-
- getLockedInodes() - Method in class alluxio.master.file.meta.SimpleInodeLockList
-
- getLockedInodeViews() - Method in interface alluxio.master.file.meta.InodeLockList
-
- getLockMode() - Method in class alluxio.master.file.meta.CompositeInodeLockList
-
- getLockMode() - Method in interface alluxio.master.file.meta.InodeLockList
-
- getLockMode() - Method in class alluxio.master.file.meta.SimpleInodeLockList
-
- getLockPattern() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getLockPoolSize() - Method in class alluxio.master.file.MetadataSyncLockManager
-
- getLockVersion() - Method in class alluxio.master.metastore.rocks.RocksSharedLockHandle
-
Gets the version on the lock.
- getLogDir() - Method in class alluxio.master.journal.ufs.UfsJournal
-
- getLogicalName() - Method in class alluxio.uri.EmbeddedLogicalAuthority
-
- getLogicalName() - Method in class alluxio.uri.ZookeeperLogicalAuthority
-
- getLogicalProcessorCount() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter.JobWorkerHealthReport
-
Returns the system logical processor count.
- getLogName() - Method in class alluxio.wire.LogInfo
-
- getLogs() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
-
- getLong(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the long integer representation of the value for the given key.
- getLong(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the long integer representation of the value for the given key.
- getLong(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getLong() - Method in class alluxio.master.journal.checkpoint.LongCheckpointFormat.LongCheckpointReader
-
- getLong(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getLongestRunning(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunning(int) - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunning(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunning() - Method in class alluxio.job.wire.JobServiceSummary
-
- getLongestRunningBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningCount() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningCount() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningCount() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningJobs() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Get the longest running jobs.
- getLongestRunningList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningList() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningOrBuilder(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongestRunningOrBuilderList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- getLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- getLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- getLongStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- getLongStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- getLongStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- getLongStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- getLongStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- getLongType() - Method in class alluxio.grpc.table.Value.Builder
-
int64 long_type = 1;
- getLongType() - Method in class alluxio.grpc.table.Value
-
int64 long_type = 1;
- getLongType() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
int64 long_type = 1;
- getLosePrimacyTime() - Method in class alluxio.wire.MasterInfo
-
- getLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional int64 losePrimacyTimeMs = 3;
- getLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
optional int64 losePrimacyTimeMs = 3;
- getLosePrimacyTimeMs() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
-
optional int64 losePrimacyTimeMs = 3;
- getLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional int64 losePrimacyTimeMs = 3;
- getLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions
-
optional int64 losePrimacyTimeMs = 3;
- getLosePrimacyTimeMs() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
optional int64 losePrimacyTimeMs = 3;
- getLosePrimacyTimeMs() - Method in class alluxio.master.meta.JobMasterInfo
-
- getLosePrimacyTimeMs() - Method in class alluxio.master.meta.MasterInfo
-
- getLostBlocksCount() - Method in interface alluxio.master.block.BlockMaster
-
- getLostBlocksCount() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getLostBlocksIterator() - Method in interface alluxio.master.block.BlockMaster
-
Returns an
Iterator
over the lost blocks.
- getLostBlocksIterator() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getLostFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getLostFiles() - Method in interface alluxio.master.file.FileSystemMaster
-
- getLostMasterInfos() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getLostMasterInfos() - Method in interface alluxio.master.meta.MetaMaster
-
- getLostMasterInfos() - Method in class alluxio.wire.MasterWebUIMasters
-
Get info of lost masters.
- getLostStorage() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
Deprecated.
- getLostStorage() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
Deprecated.
- getLostStorage() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
Deprecated.
- getLostStorage() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
Deprecated.
- getLostStorage() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
Deprecated.
- getLostStorage() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
Deprecated.
- getLostStorage() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
Deprecated.
- getLostStorage() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
Deprecated.
- getLostStorage() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
-
Deprecated.
- getLostStorage() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- getLostStorage() - Method in class alluxio.worker.block.BlockHeartbeatReport
-
Gets the storage paths which were lost
in the heartbeat this report represents.
- getLostStorage() - Method in interface alluxio.worker.block.BlockStoreMeta
-
- getLostStorage() - Method in interface alluxio.worker.block.meta.StorageTier
-
- getLostStorageCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- getLostStorageCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
- getLostStorageCount() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of lost storage paths on all tiers
- getLostStorageCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- getLostStorageCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
- getLostStorageCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of tier alias to a list of lost storage paths.
- getLostStorageCount() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- getLostStorageCount() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
- getLostStorageCount() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
-
a map from tier alias to the lost storage paths
- getLostStorageMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of lost storage paths on all tiers
- getLostStorageMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of lost storage paths on all tiers
- getLostStorageMap() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of lost storage paths on all tiers
- getLostStorageMap() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of tier alias to a list of lost storage paths.
- getLostStorageMap() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of tier alias to a list of lost storage paths.
- getLostStorageMap() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of tier alias to a list of lost storage paths.
- getLostStorageMap() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
a map from tier alias to the lost storage paths
- getLostStorageMap() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
a map from tier alias to the lost storage paths
- getLostStorageMap() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
-
a map from tier alias to the lost storage paths
- getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of lost storage paths on all tiers
- getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of lost storage paths on all tiers
- getLostStorageOrDefault(String, StorageList) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of lost storage paths on all tiers
- getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of tier alias to a list of lost storage paths.
- getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of tier alias to a list of lost storage paths.
- getLostStorageOrDefault(String, StorageList) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of tier alias to a list of lost storage paths.
- getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
a map from tier alias to the lost storage paths
- getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.WorkerLostStorageInfo
-
a map from tier alias to the lost storage paths
- getLostStorageOrDefault(String, StorageList) - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
-
a map from tier alias to the lost storage paths
- getLostStorageOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of lost storage paths on all tiers
- getLostStorageOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of lost storage paths on all tiers
- getLostStorageOrThrow(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of lost storage paths on all tiers
- getLostStorageOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of tier alias to a list of lost storage paths.
- getLostStorageOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of tier alias to a list of lost storage paths.
- getLostStorageOrThrow(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of tier alias to a list of lost storage paths.
- getLostStorageOrThrow(String) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
a map from tier alias to the lost storage paths
- getLostStorageOrThrow(String) - Method in class alluxio.grpc.WorkerLostStorageInfo
-
a map from tier alias to the lost storage paths
- getLostStorageOrThrow(String) - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
-
a map from tier alias to the lost storage paths
- getLostWorkerCount() - Method in interface alluxio.master.block.BlockMaster
-
- getLostWorkerCount() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getLostWorkerInfoList() - Method in interface alluxio.client.block.BlockMasterClient
-
Gets the worker information of lost workers.
- getLostWorkerInfoList() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getLostWorkerList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
-
Returns a list of workers information.
- getLostWorkerList(GetWorkerInfoListPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
-
Returns a list of workers information.
- getLostWorkerList(GetWorkerInfoListPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
-
Returns a list of workers information.
- getLostWorkerList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
-
Returns a list of workers information.
- getLostWorkerList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
-
- getLostWorkerList() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getLostWorkerList() - Method in interface alluxio.master.file.FileSystemMaster
-
- getLostWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 lostWorkerNum = 5;
- getLostWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int32 lostWorkerNum = 5;
- getLostWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int32 lostWorkerNum = 5;
- getLostWorkerNum() - Method in class alluxio.wire.BlockMasterInfo
-
- getLostWorkers() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get lost workers.
- getLostWorkers() - Method in class alluxio.client.file.FileSystemContext
-
Gets the lost worker information list.
- getLostWorkers() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getLostWorkersInfoList() - Method in interface alluxio.master.block.BlockMaster
-
- getLostWorkersInfoList() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getLow() - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value low = 1;
- getLow() - Method in class alluxio.grpc.table.Range
-
optional .alluxio.grpc.table.Value low = 1;
- getLow() - Method in interface alluxio.grpc.table.RangeOrBuilder
-
optional .alluxio.grpc.table.Value low = 1;
- getLowBuilder() - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value low = 1;
- getLowOrBuilder() - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value low = 1;
- getLowOrBuilder() - Method in class alluxio.grpc.table.Range
-
optional .alluxio.grpc.table.Value low = 1;
- getLowOrBuilder() - Method in interface alluxio.grpc.table.RangeOrBuilder
-
optional .alluxio.grpc.table.Value low = 1;
- getLowValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date low_value = 1;
- getLowValue() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional .alluxio.grpc.table.Date low_value = 1;
- getLowValue() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Date low_value = 1;
- getLowValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- getLowValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- getLowValue() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- getLowValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional double low_value = 1;
- getLowValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional double low_value = 1;
- getLowValue() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional double low_value = 1;
- getLowValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 low_value = 1;
- getLowValue() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional int64 low_value = 1;
- getLowValue() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional int64 low_value = 1;
- getLowValueBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date low_value = 1;
- getLowValueBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- getLowValueOrBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date low_value = 1;
- getLowValueOrBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional .alluxio.grpc.table.Date low_value = 1;
- getLowValueOrBuilder() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Date low_value = 1;
- getLowValueOrBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- getLowValueOrBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- getLowValueOrBuilder() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- getLowWaterMark() - Method in class alluxio.master.metastore.caching.CacheConfiguration
-
- getMappingPath() - Method in class alluxio.worker.http.HttpRequestUri
-
Get the mapping path of the request URI.
- getMarker() - Method in class alluxio.s3.ListBucketOptions
-
- getMarker() - Method in class alluxio.s3.ListBucketResult
-
- getMask() - Method in class alluxio.security.authorization.ExtendedACLEntries
-
- getMaskActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- getMaskActions() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- getMaskActions() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- getMaskActionsBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- getMaskActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- getMaskActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- getMaskActionsOrBuilder() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- getMaster() - Method in class alluxio.master.LocalAlluxioJobCluster
-
- getMaster(Class<T>) - Method in class alluxio.master.MasterProcess
-
- getMasterAddress() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get master address.
- getMasterAddress() - Method in class alluxio.client.file.FileSystemContext
-
- getMasterAddress() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddress() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddress() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddress() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddress() - Method in class alluxio.grpc.GetMasterIdPRequest
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddress() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddress() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- getMasterAddress() - Method in class alluxio.grpc.JobMasterStatus
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- getMasterAddress() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- getMasterAddress() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getMasterAddress() - Method in interface alluxio.master.meta.MetaMaster
-
- getMasterAddress() - Method in class alluxio.worker.block.BlockMasterClientPool
-
- getMasterAddressBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddressBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddressBuilder() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- getMasterAddresses() - Method in class alluxio.client.block.AllMastersWorkerInfo
-
- getMasterAddresses(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddresses(int) - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddresses(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddresses() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getMasterAddresses() - Method in interface alluxio.master.meta.MetaMaster
-
- getMasterAddresses() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- getMasterAddresses() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- getMasterAddresses() - Method in class alluxio.multi.process.MultiProcessCluster
-
- getMasterAddresses() - Method in class alluxio.uri.MultiMasterAuthority
-
- getMasterAddressesBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesCount() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesCount() - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesCount() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesList() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesList() - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesOrBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesOrBuilder(int) - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesOrBuilder(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesOrBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesOrBuilderList() - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressesOrBuilderList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- getMasterAddressOrBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddressOrBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddressOrBuilder() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddressOrBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddressOrBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddressOrBuilder() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- getMasterAddressOrBuilder() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- getMasterAddressOrBuilder() - Method in class alluxio.grpc.JobMasterStatus
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- getMasterAddressOrBuilder() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- getMasterCapacityFreePercentage() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets master capacity free percentage.
- getMasterCapacityUsedPercentage() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets master capacity used percentage.
- getMasterClientContext() - Method in class alluxio.client.file.FileSystemContext
-
- getMasterContext() - Method in class alluxio.master.AbstractMaster
-
- getMasterContext() - Method in interface alluxio.master.Master
-
- getMasterContext() - Method in class alluxio.master.NoopMaster
-
- getMasterContext() - Method in class alluxio.worker.block.BlockMasterClientPool
-
- getMasterEmbeddedJournalAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
-
- getMasterForEntry(Journal.JournalEntry) - Static method in class alluxio.master.journal.JournalEntryAssociation
-
- getMasterHeartbeatMethod() - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
-
- getMasterHeartbeatMethod() - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
-
- getMasterHostname() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
The hostname of the master that did the checkpoint
- getMasterHostname() - Method in class alluxio.grpc.CheckpointPResponse
-
The hostname of the master that did the checkpoint
- getMasterHostname() - Method in interface alluxio.grpc.CheckpointPResponseOrBuilder
-
The hostname of the master that did the checkpoint
- getMasterHostname() - Method in class alluxio.wire.WorkerWebUIInit
-
Gets master ip.
- getMasterHostnameBytes() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
The hostname of the master that did the checkpoint
- getMasterHostnameBytes() - Method in class alluxio.grpc.CheckpointPResponse
-
The hostname of the master that did the checkpoint
- getMasterHostnameBytes() - Method in interface alluxio.grpc.CheckpointPResponseOrBuilder
-
The hostname of the master that did the checkpoint
- getMasterHostnames(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
-
Gets list of masters in conf directory.
- getMasterHostNotConfiguredMessage(String) - Static method in class alluxio.util.ConfigurationUtils
-
Returns a unified message for cases when the master hostname cannot be determined.
- getMasterId() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
optional int64 masterId = 1;
- getMasterId() - Method in class alluxio.grpc.GetJobMasterIdPResponse
-
optional int64 masterId = 1;
- getMasterId() - Method in interface alluxio.grpc.GetJobMasterIdPResponseOrBuilder
-
optional int64 masterId = 1;
- getMasterId() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
optional int64 masterId = 1;
- getMasterId() - Method in class alluxio.grpc.GetMasterIdPResponse
-
optional int64 masterId = 1;
- getMasterId() - Method in interface alluxio.grpc.GetMasterIdPResponseOrBuilder
-
optional int64 masterId = 1;
- getMasterId() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional int64 masterId = 1;
- getMasterId() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
optional int64 masterId = 1;
- getMasterId() - Method in interface alluxio.grpc.JobMasterHeartbeatPRequestOrBuilder
-
optional int64 masterId = 1;
- getMasterId(GetJobMasterIdPRequest, StreamObserver<GetJobMasterIdPResponse>) - Method in interface alluxio.grpc.JobMasterMasterServiceGrpc.AsyncService
-
Returns a master id for the given master address.
- getMasterId(GetJobMasterIdPRequest) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceBlockingStub
-
Returns a master id for the given master address.
- getMasterId(GetJobMasterIdPRequest) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceFutureStub
-
Returns a master id for the given master address.
- getMasterId(GetJobMasterIdPRequest, StreamObserver<GetJobMasterIdPResponse>) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceStub
-
Returns a master id for the given master address.
- getMasterId() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional int64 masterId = 1;
- getMasterId() - Method in class alluxio.grpc.MasterHeartbeatPRequest
-
optional int64 masterId = 1;
- getMasterId() - Method in interface alluxio.grpc.MasterHeartbeatPRequestOrBuilder
-
optional int64 masterId = 1;
- getMasterId(GetMasterIdPRequest, StreamObserver<GetMasterIdPResponse>) - Method in interface alluxio.grpc.MetaMasterMasterServiceGrpc.AsyncService
-
Returns a master id for the given master address.
- getMasterId(GetMasterIdPRequest) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceBlockingStub
-
Returns a master id for the given master address.
- getMasterId(GetMasterIdPRequest) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceFutureStub
-
Returns a master id for the given master address.
- getMasterId(GetMasterIdPRequest, StreamObserver<GetMasterIdPResponse>) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceStub
-
Returns a master id for the given master address.
- getMasterId() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional int64 masterId = 1;
- getMasterId() - Method in class alluxio.grpc.RegisterMasterPRequest
-
optional int64 masterId = 1;
- getMasterId() - Method in interface alluxio.grpc.RegisterMasterPRequestOrBuilder
-
optional int64 masterId = 1;
- getMasterId(Address) - Method in class alluxio.master.job.JobMaster
-
Allocates an ID for the job master from the target address.
- getMasterId(Address) - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getMasterId(GetJobMasterIdPRequest, StreamObserver<GetJobMasterIdPResponse>) - Method in class alluxio.master.meta.JobMasterMasterServiceHandler
-
- getMasterId(Address) - Method in interface alluxio.master.meta.MetaMaster
-
Returns a master id for the given master, creating one if the master is new.
- getMasterId(GetMasterIdPRequest, StreamObserver<GetMasterIdPResponse>) - Method in class alluxio.master.meta.MetaMasterMasterServiceHandler
-
- GetMasterIdPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetMasterIdPOptions
- GetMasterIdPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetMasterIdPOptions
- GetMasterIdPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetMasterIdPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetMasterIdPRequest
- GetMasterIdPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetMasterIdPRequest
- GetMasterIdPRequestOrBuilder - Interface in alluxio.grpc
-
- GetMasterIdPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetMasterIdPResponse
- GetMasterIdPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetMasterIdPResponse
- GetMasterIdPResponseOrBuilder - Interface in alluxio.grpc
-
- getMasterInfo(Set<MasterInfoField>) - Method in interface alluxio.client.meta.MetaMasterClient
-
- getMasterInfo(Set<MasterInfoField>) - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
-
- getMasterInfo() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- getMasterInfo() - Method in class alluxio.grpc.GetMasterInfoPResponse
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- getMasterInfo() - Method in interface alluxio.grpc.GetMasterInfoPResponseOrBuilder
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- getMasterInfo(GetMasterInfoPOptions, StreamObserver<GetMasterInfoPResponse>) - Method in interface alluxio.grpc.MetaMasterClientServiceGrpc.AsyncService
-
Returns information about the master.
- getMasterInfo(GetMasterInfoPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
-
Returns information about the master.
- getMasterInfo(GetMasterInfoPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
-
Returns information about the master.
- getMasterInfo(GetMasterInfoPOptions, StreamObserver<GetMasterInfoPResponse>) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
-
Returns information about the master.
- getMasterInfo(GetMasterInfoPOptions, StreamObserver<GetMasterInfoPResponse>) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
-
- getMasterInfoBuilder() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- getMasterInfoOrBuilder() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- getMasterInfoOrBuilder() - Method in class alluxio.grpc.GetMasterInfoPResponse
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- getMasterInfoOrBuilder() - Method in interface alluxio.grpc.GetMasterInfoPResponseOrBuilder
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- GetMasterInfoPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetMasterInfoPOptions
- GetMasterInfoPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetMasterInfoPOptions
- GetMasterInfoPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetMasterInfoPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetMasterInfoPResponse
- GetMasterInfoPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.GetMasterInfoPResponse
- GetMasterInfoPResponseOrBuilder - Interface in alluxio.grpc
-
- getMasterInquireClient() - Method in class alluxio.master.MasterClientContext
-
- getMasterInquireClient() - Method in class alluxio.multi.process.MultiProcessCluster
-
- getMasterMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
-
Builds metric registry names for master instance.
- getMasterMetrics(Set<String>) - Static method in class alluxio.metrics.MetricsSystem
-
Gets all the master metrics belongs to the given metric names.
- getMasterNodeAddress() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets master node address.
- getMasterNodeAddress() - Method in class alluxio.wire.MasterWebUIData
-
Gets master node address.
- getMasterNodeAddress() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets master node address.
- getMasterPort() - Method in class alluxio.wire.WorkerWebUIInit
-
Gets master port.
- getMasterProcess() - Method in class alluxio.master.LocalAlluxioMaster
-
- getMasterRole() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets master role name.
- getMasterRpcAddresses() - Method in interface alluxio.master.MasterInquireClient
-
- getMasterRpcAddresses() - Method in class alluxio.master.PollingMasterInquireClient
-
- getMasterRpcAddresses() - Method in class alluxio.master.SingleMasterInquireClient
-
- getMasterRpcAddresses() - Method in class alluxio.master.ZkMasterInquireClient
-
- getMasterRpcAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
-
Gets the RPC addresses of all masters based on the configuration.
- getMasterRpcPort() - Method in class alluxio.master.LocalAlluxioCluster
-
- getMasterServiceHandler() - Method in class alluxio.master.metrics.DefaultMetricsMaster
-
- getMasterServiceHandler() - Method in interface alluxio.master.metrics.MetricsMaster
-
- getMasterServiceLoader() - Static method in class alluxio.master.ServiceUtils
-
- getMasterServiceNames() - Static method in class alluxio.master.ServiceUtils
-
- getMasterStatus() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Get master status.
- getMasterUnderfsCapacityFreePercentage() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets master underfs capacity free percentage.
- getMasterUnderfsCapacityUsedPercentage() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets master underfs capacity used percentage.
- getMasterURI() - Method in class alluxio.master.LocalAlluxioCluster
-
- getMasterVersions() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get master versions.
- getMasterVersions(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersions(int) - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersions(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsCount() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsCount() - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsCount() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsList() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsList() - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsOrBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsOrBuilder(int) - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsOrBuilder(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsOrBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsOrBuilderList() - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMasterVersionsOrBuilderList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- getMaxCapacity() - Method in class alluxio.resource.DynamicResourcePool.Options
-
- getMaxColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional int64 max_col_len = 1;
- getMaxColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
optional int64 max_col_len = 1;
- getMaxColLen() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
-
optional int64 max_col_len = 1;
- getMaxColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 max_col_len = 1;
- getMaxColLen() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional int64 max_col_len = 1;
- getMaxColLen() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional int64 max_col_len = 1;
- getMaxEvictionRetries() - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- getMaxKeys() - Method in class alluxio.s3.ListBucketOptions
-
- getMaxKeys() - Method in class alluxio.s3.ListBucketResult
-
- getMaxSequenceNumber() - Static method in class alluxio.master.block.BlockId
-
- getMaxSize() - Method in class alluxio.master.metastore.caching.CacheConfiguration
-
- getMaxTimeNs() - Method in class alluxio.stress.cli.Benchmark.MethodStatistics
-
- getMaxUfsReadConcurrency() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional int32 maxUfsReadConcurrency = 2;
- getMaxUfsReadConcurrency() - Method in class alluxio.grpc.OpenFilePOptions
-
optional int32 maxUfsReadConcurrency = 2;
- getMaxUfsReadConcurrency() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional int32 maxUfsReadConcurrency = 2;
- getMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional int32 maxUfsReadConcurrency = 4;
- getMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
optional int32 maxUfsReadConcurrency = 4;
- getMaxUfsReadConcurrency() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
optional int32 maxUfsReadConcurrency = 4;
- getMechanismName() - Method in class alluxio.security.authentication.plain.PlainSaslServer
-
- getMechanismNames(Map<String, ?>) - Method in class alluxio.security.authentication.plain.PlainSaslServer.Factory
-
- getMedium() - Method in class alluxio.worker.block.CreateBlockOptions
-
- getMediumType() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getMediumType() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string mediumType = 4;
- getMediumType() - Method in class alluxio.grpc.BlockLocation
-
optional string mediumType = 4;
- getMediumType() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional string mediumType = 4;
- getMediumType() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string mediumType = 2;
- getMediumType() - Method in class alluxio.grpc.BlockStoreLocationProto
-
optional string mediumType = 2;
- getMediumType() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
-
optional string mediumType = 2;
- getMediumType() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional string mediumType = 7;
- getMediumType() - Method in class alluxio.grpc.CommitBlockPRequest
-
optional string mediumType = 7;
- getMediumType() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
optional string mediumType = 7;
- getMediumType(int) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated string mediumType = 33;
- getMediumType(int) - Method in class alluxio.grpc.FileInfo
-
repeated string mediumType = 33;
- getMediumType(int) - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated string mediumType = 33;
- getMediumType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional string medium_type = 2;
- getMediumType() - Method in class alluxio.grpc.MoveBlockRequest
-
optional string medium_type = 2;
- getMediumType() - Method in interface alluxio.grpc.MoveBlockRequestOrBuilder
-
optional string medium_type = 2;
- getMediumType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional string medium_type = 8;
- getMediumType() - Method in class alluxio.grpc.WriteRequestCommand
-
optional string medium_type = 8;
- getMediumType() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional string medium_type = 8;
- getMediumType() - Method in class alluxio.job.plan.replicate.MoveConfig
-
- getMediumType(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
repeated string medium_type = 18;
- getMediumType(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
repeated string medium_type = 18;
- getMediumType(int) - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
repeated string medium_type = 18;
- getMediumType(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated string medium_type = 26;
- getMediumType(int) - Method in class alluxio.proto.journal.File.InodeFileEntry
-
repeated string medium_type = 26;
- getMediumType(int) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
repeated string medium_type = 26;
- getMediumType(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
repeated string medium_type = 16;
- getMediumType(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
repeated string medium_type = 16;
- getMediumType(int) - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
repeated string medium_type = 16;
- getMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string mediumType = 3;
- getMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation
-
optional string mediumType = 3;
- getMediumType() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
-
optional string mediumType = 3;
- getMediumType(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated string medium_type = 27;
- getMediumType(int) - Method in class alluxio.proto.meta.InodeMeta.Inode
-
repeated string medium_type = 27;
- getMediumType(int) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
repeated string medium_type = 27;
- getMediumType() - Method in class alluxio.wire.BlockLocation
-
- getMediumTypeBytes() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string mediumType = 4;
- getMediumTypeBytes() - Method in class alluxio.grpc.BlockLocation
-
optional string mediumType = 4;
- getMediumTypeBytes() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional string mediumType = 4;
- getMediumTypeBytes() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string mediumType = 2;
- getMediumTypeBytes() - Method in class alluxio.grpc.BlockStoreLocationProto
-
optional string mediumType = 2;
- getMediumTypeBytes() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
-
optional string mediumType = 2;
- getMediumTypeBytes() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional string mediumType = 7;
- getMediumTypeBytes() - Method in class alluxio.grpc.CommitBlockPRequest
-
optional string mediumType = 7;
- getMediumTypeBytes() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
optional string mediumType = 7;
- getMediumTypeBytes(int) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated string mediumType = 33;
- getMediumTypeBytes(int) - Method in class alluxio.grpc.FileInfo
-
repeated string mediumType = 33;
- getMediumTypeBytes(int) - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated string mediumType = 33;
- getMediumTypeBytes() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional string medium_type = 2;
- getMediumTypeBytes() - Method in class alluxio.grpc.MoveBlockRequest
-
optional string medium_type = 2;
- getMediumTypeBytes() - Method in interface alluxio.grpc.MoveBlockRequestOrBuilder
-
optional string medium_type = 2;
- getMediumTypeBytes() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional string medium_type = 8;
- getMediumTypeBytes() - Method in class alluxio.grpc.WriteRequestCommand
-
optional string medium_type = 8;
- getMediumTypeBytes() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional string medium_type = 8;
- getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
repeated string medium_type = 18;
- getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
repeated string medium_type = 18;
- getMediumTypeBytes(int) - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
repeated string medium_type = 18;
- getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated string medium_type = 26;
- getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.InodeFileEntry
-
repeated string medium_type = 26;
- getMediumTypeBytes(int) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
repeated string medium_type = 26;
- getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
repeated string medium_type = 16;
- getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
repeated string medium_type = 16;
- getMediumTypeBytes(int) - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
repeated string medium_type = 16;
- getMediumTypeBytes() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string mediumType = 3;
- getMediumTypeBytes() - Method in class alluxio.proto.meta.Block.BlockLocation
-
optional string mediumType = 3;
- getMediumTypeBytes() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
-
optional string mediumType = 3;
- getMediumTypeBytes(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated string medium_type = 27;
- getMediumTypeBytes(int) - Method in class alluxio.proto.meta.InodeMeta.Inode
-
repeated string medium_type = 27;
- getMediumTypeBytes(int) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
repeated string medium_type = 27;
- getMediumTypeCount() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated string mediumType = 33;
- getMediumTypeCount() - Method in class alluxio.grpc.FileInfo
-
repeated string mediumType = 33;
- getMediumTypeCount() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated string mediumType = 33;
- getMediumTypeCount() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
repeated string medium_type = 18;
- getMediumTypeCount() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
repeated string medium_type = 18;
- getMediumTypeCount() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
repeated string medium_type = 18;
- getMediumTypeCount() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated string medium_type = 26;
- getMediumTypeCount() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
repeated string medium_type = 26;
- getMediumTypeCount() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
repeated string medium_type = 26;
- getMediumTypeCount() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
repeated string medium_type = 16;
- getMediumTypeCount() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
repeated string medium_type = 16;
- getMediumTypeCount() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
repeated string medium_type = 16;
- getMediumTypeCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated string medium_type = 27;
- getMediumTypeCount() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
repeated string medium_type = 27;
- getMediumTypeCount() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
repeated string medium_type = 27;
- getMediumTypeList() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated string mediumType = 33;
- getMediumTypeList() - Method in class alluxio.grpc.FileInfo
-
repeated string mediumType = 33;
- getMediumTypeList() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated string mediumType = 33;
- getMediumTypeList() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
repeated string medium_type = 18;
- getMediumTypeList() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
repeated string medium_type = 18;
- getMediumTypeList() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
repeated string medium_type = 18;
- getMediumTypeList() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated string medium_type = 26;
- getMediumTypeList() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
repeated string medium_type = 26;
- getMediumTypeList() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
repeated string medium_type = 26;
- getMediumTypeList() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
repeated string medium_type = 16;
- getMediumTypeList() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
repeated string medium_type = 16;
- getMediumTypeList() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
repeated string medium_type = 16;
- getMediumTypeList() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated string medium_type = 27;
- getMediumTypeList() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
repeated string medium_type = 27;
- getMediumTypeList() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
repeated string medium_type = 27;
- getMediumTypes() - Method in class alluxio.master.file.meta.Inode
-
- getMediumTypes() - Method in interface alluxio.master.file.meta.InodeView
-
- getMediumTypes() - Method in class alluxio.master.file.meta.MutableInode
-
- getMediumTypes() - Method in class alluxio.wire.FileInfo
-
- getMemoryPoolNames() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
-
- getMergedJournalEntries() - Method in class alluxio.master.file.FileSystemJournalEntryMerger
-
- getMergedJournalEntries() - Method in interface alluxio.master.journal.JournalEntryMerger
-
Returns a list of journal entries which have been merged.
- getMerger() - Method in class alluxio.master.journal.MetadataSyncMergeJournalContext
-
- getMessage() - Method in enum alluxio.cli.fsadmin.command.DecommissionWorkerCommand.ReturnCode
-
Gets the message.
- getMessage(String) - Static method in class alluxio.conf.RemovedKey
-
gets the message pertaining to a removed key or template.
- getMessage() - Method in exception alluxio.exception.AggregateException
-
- getMessage(Object...) - Method in enum alluxio.exception.ExceptionMessage
-
Formats the message of the exception.
- getMessage() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
-
- getMessage() - Method in class alluxio.grpc.BlockStatus.Builder
-
A developer-facing error message
- getMessage() - Method in class alluxio.grpc.BlockStatus
-
A developer-facing error message
- getMessage() - Method in interface alluxio.grpc.BlockStatusOrBuilder
-
A developer-facing error message
- getMessage() - Method in class alluxio.grpc.DataMessage
-
- getMessage() - Method in class alluxio.grpc.FileFailure.Builder
-
A developer-facing error message
- getMessage() - Method in class alluxio.grpc.FileFailure
-
A developer-facing error message
- getMessage() - Method in interface alluxio.grpc.FileFailureOrBuilder
-
A developer-facing error message
- getMessage() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
A developer-facing error message
- getMessage() - Method in class alluxio.grpc.LoadFileFailure
-
A developer-facing error message
- getMessage() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
-
A developer-facing error message
- getMessage() - Method in class alluxio.grpc.RouteFailure.Builder
-
A developer-facing error message
- getMessage() - Method in class alluxio.grpc.RouteFailure
-
A developer-facing error message
- getMessage() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
A developer-facing error message
- getMessage() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional bytes message = 2;
- getMessage() - Method in class alluxio.grpc.SaslMessage
-
optional bytes message = 2;
- getMessage() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional bytes message = 2;
- getMessage() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional bytes message = 3;
- getMessage() - Method in class alluxio.grpc.TransportMessage
-
optional bytes message = 3;
- getMessage() - Method in interface alluxio.grpc.TransportMessageOrBuilder
-
optional bytes message = 3;
- getMessage() - Method in class alluxio.network.protocol.RPCProtoMessage
-
- getMessage() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional string message = 2;
- getMessage() - Method in class alluxio.proto.dataserver.Protocol.Response
-
optional string message = 2;
- getMessage() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
-
optional string message = 2;
- getMessage() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- getMessage() - Method in class alluxio.RestUtils.ErrorResponse
-
Gets message.
- getMessage() - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
-
- getMessage() - Method in class alluxio.s3.S3Error
-
- getMessage() - Method in class alluxio.wire.LogInfo
-
- getMessageBytes() - Method in class alluxio.grpc.BlockStatus.Builder
-
A developer-facing error message
- getMessageBytes() - Method in class alluxio.grpc.BlockStatus
-
A developer-facing error message
- getMessageBytes() - Method in interface alluxio.grpc.BlockStatusOrBuilder
-
A developer-facing error message
- getMessageBytes() - Method in class alluxio.grpc.FileFailure.Builder
-
A developer-facing error message
- getMessageBytes() - Method in class alluxio.grpc.FileFailure
-
A developer-facing error message
- getMessageBytes() - Method in interface alluxio.grpc.FileFailureOrBuilder
-
A developer-facing error message
- getMessageBytes() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
A developer-facing error message
- getMessageBytes() - Method in class alluxio.grpc.LoadFileFailure
-
A developer-facing error message
- getMessageBytes() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
-
A developer-facing error message
- getMessageBytes() - Method in class alluxio.grpc.RouteFailure.Builder
-
A developer-facing error message
- getMessageBytes() - Method in class alluxio.grpc.RouteFailure
-
A developer-facing error message
- getMessageBytes() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
A developer-facing error message
- getMessageBytes() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional string message = 2;
- getMessageBytes() - Method in class alluxio.proto.dataserver.Protocol.Response
-
optional string message = 2;
- getMessageBytes() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
-
optional string message = 2;
- getMessageType() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
- getMessageType() - Method in class alluxio.grpc.SaslMessage
-
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
- getMessageType() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
- getMessageWithUrl(String, Object...) - Method in enum alluxio.exception.ExceptionMessage
-
Formats the message of the exception with an url to consult.
- getMeta() - Method in class alluxio.master.metastore.BlockMetaStore.Block
-
- getMetaClient() - Method in class alluxio.cli.fsadmin.command.Context
-
- getMetadataCacheExpireTime() - Method in class alluxio.fuse.options.MountOptions
-
- getMetadataCacheSize() - Method in class alluxio.client.file.MetadataCachingFileSystem
-
- getMetadataCacheSize() - Method in class alluxio.fuse.options.MountOptions
-
- getMetadataSyncRpcContext() - Method in class alluxio.master.file.InodeSyncStream
-
- getMetaFS() - Method in class alluxio.proxy.s3.S3Handler
-
Get system user FileSystem object.
- getMetaMasterClient() - Method in class alluxio.multi.process.Clients
-
- getMetaMasterClient() - Method in class alluxio.multi.process.MultiProcessCluster
-
- getMeter() - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- getMeter() - Method in class alluxio.worker.grpc.WriteRequestContext
-
- getMethod() - Method in class alluxio.stress.cli.Benchmark.ProfileInput
-
- getMetricCounter() - Method in class alluxio.client.block.BlockMasterClientPool
-
- getMetricCounter() - Method in class alluxio.client.block.stream.BlockWorkerClientPool
-
- getMetricCounter() - Method in class alluxio.client.file.FileSystemMasterClientPool
-
- getMetricCounter() - Method in class alluxio.network.netty.NettyChannelPool
-
- getMetricCounter() - Method in class alluxio.resource.DynamicResourcePool
-
- getMetricName() - Method in class alluxio.metrics.MetricKey
-
- getMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
-
Converts a simple string to a qualified metric name based on the process type.
- getMetricNameWithTags(String, String...) - Static method in class alluxio.metrics.Metric
-
Gets the metric name with the appendix of tags.
- getMetricNameWithUserTag(String, String) - Static method in class alluxio.metrics.Metric
-
Gets a metric name with a specific user tag.
- getMetricRegistry() - Method in class alluxio.metrics.source.JvmSource
-
- getMetricRegistry() - Method in interface alluxio.metrics.source.Source
-
Gets the instance of the MetricRegistry
.
- getMetrics() - Method in interface alluxio.client.metrics.MetricsMasterClient
-
Gets all the metrics stored in the current master from metric name to metric value.
- getMetrics() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
-
- getMetrics(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetrics(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetrics(int) - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetrics(int) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetrics(int) - Method in class alluxio.grpc.ClientMetrics
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetrics(int) - Method in interface alluxio.grpc.ClientMetricsOrBuilder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetrics() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
Deprecated.
- getMetrics() - Method in class alluxio.grpc.GetMetricsPResponse
-
Deprecated.
- getMetrics() - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
-
Deprecated.
- getMetrics(GetMetricsPOptions, StreamObserver<GetMetricsPResponse>) - Method in interface alluxio.grpc.MetricsMasterClientServiceGrpc.AsyncService
-
Returns a map of metrics property names and their values from Alluxio metrics system.
- getMetrics(GetMetricsPOptions) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceBlockingStub
-
Returns a map of metrics property names and their values from Alluxio metrics system.
- getMetrics(GetMetricsPOptions) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceFutureStub
-
Returns a map of metrics property names and their values from Alluxio metrics system.
- getMetrics(GetMetricsPOptions, StreamObserver<GetMetricsPResponse>) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceStub
-
Returns a map of metrics property names and their values from Alluxio metrics system.
- getMetrics() - Method in class alluxio.master.metrics.DefaultMetricsMaster
-
- getMetrics() - Method in interface alluxio.master.metrics.MetricsMaster
-
- getMetrics(GetMetricsPOptions, StreamObserver<GetMetricsPResponse>) - Method in class alluxio.master.metrics.MetricsMasterClientServiceHandler
-
- getMetrics() - Method in class alluxio.metrics.OperationSystemGaugeSet
-
- getMetrics() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getMetrics() - Method in class alluxio.wire.AlluxioWorkerInfo
-
- getMetricsBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsBuilder(int) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsBuilderList() - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsClient() - Method in class alluxio.cli.fsadmin.command.Context
-
- getMetricsCount() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsCount() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsCount() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsCount() - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsCount() - Method in class alluxio.grpc.ClientMetrics
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsCount() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsCount() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- getMetricsCount() - Method in class alluxio.grpc.GetMetricsPResponse
-
- getMetricsCount() - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- getMetricsHeartbeatMethod() - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
-
- getMetricsInfo() - Method in class alluxio.cli.fsadmin.report.MetricsOutput
-
Get metrics info.
- getMetricsJson(String) - Static method in class alluxio.cli.bundler.command.CollectMetricsCommand
-
Probes Alluxio metrics json sink.
- getMetricsList() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsList() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsList() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsList() - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsList() - Method in class alluxio.grpc.ClientMetrics
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsList() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsMap() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- getMetricsMap() - Method in class alluxio.grpc.GetMetricsPResponse
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- getMetricsMap() - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- getMetricsMasterClient() - Method in class alluxio.multi.process.MultiProcessCluster
-
- getMetricsOrBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsOrBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsOrBuilder(int) - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsOrBuilder(int) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsOrBuilder(int) - Method in class alluxio.grpc.ClientMetrics
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsOrBuilder(int) - Method in interface alluxio.grpc.ClientMetricsOrBuilder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsOrBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsOrBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsOrBuilderList() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
-
repeated .alluxio.grpc.Metric metrics = 1;
- getMetricsOrBuilderList() - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsOrBuilderList() - Method in class alluxio.grpc.ClientMetrics
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsOrBuilderList() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
-
repeated .alluxio.grpc.Metric metrics = 2;
- getMetricsOrDefault(String, MetricValue) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- getMetricsOrDefault(String, MetricValue) - Method in class alluxio.grpc.GetMetricsPResponse
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- getMetricsOrDefault(String, MetricValue) - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- getMetricsOrThrow(String) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- getMetricsOrThrow(String) - Method in class alluxio.grpc.GetMetricsPResponse
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- getMetricsOrThrow(String) - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- GetMetricsPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.GetMetricsPOptions
- GetMetricsPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.GetMetricsPOptions
- GetMetricsPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetMetricsPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.GetMetricsPResponse
- GetMetricsPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.GetMetricsPResponse
- GetMetricsPResponseOrBuilder - Interface in alluxio.grpc
-
- getMetricType() - Method in class alluxio.grpc.Metric.Builder
-
required .alluxio.grpc.MetricType metricType = 5;
- getMetricType() - Method in class alluxio.grpc.Metric
-
required .alluxio.grpc.MetricType metricType = 5;
- getMetricType() - Method in interface alluxio.grpc.MetricOrBuilder
-
required .alluxio.grpc.MetricType metricType = 5;
- getMetricType() - Method in class alluxio.grpc.MetricValue.Builder
-
optional .alluxio.grpc.MetricType metricType = 6;
- getMetricType() - Method in class alluxio.grpc.MetricValue
-
optional .alluxio.grpc.MetricType metricType = 6;
- getMetricType() - Method in interface alluxio.grpc.MetricValueOrBuilder
-
optional .alluxio.grpc.MetricType metricType = 6;
- getMetricType() - Method in class alluxio.metrics.Metric
-
- getMetricType() - Method in class alluxio.metrics.MetricKey
-
- getMetricValue(String) - Static method in class alluxio.metrics.MetricsSystem
-
Gets metric with the given full metric name.
- getMinCapacity() - Method in class alluxio.resource.DynamicResourcePool.Options
-
- getMode() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getMode() - Method in class alluxio.client.file.URIStatus
-
- getMode() - Method in class alluxio.fuse.file.CreateFileStatus
-
- getMode() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- getMode() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.PMode mode = 3;
- getMode() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.PMode mode = 3;
- getMode() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- getMode() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.PMode mode = 3;
- getMode() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.PMode mode = 3;
- getMode() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 mode = 18;
- getMode() - Method in class alluxio.grpc.FileInfo
-
optional int32 mode = 18;
- getMode() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int32 mode = 18;
- getMode() - Method in class alluxio.grpc.PAcl.Builder
-
optional int32 mode = 4;
- getMode() - Method in class alluxio.grpc.PAcl
-
optional int32 mode = 4;
- getMode() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional int32 mode = 4;
- getMode() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 5;
- getMode() - Method in class alluxio.grpc.SetAttributePOptions
-
optional .alluxio.grpc.PMode mode = 5;
- getMode() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional .alluxio.grpc.PMode mode = 5;
- getMode() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional int32 mode = 6;
- getMode() - Method in class alluxio.grpc.UfsStatus
-
optional int32 mode = 6;
- getMode() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional int32 mode = 6;
- getMode() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getMode() - Method in class alluxio.master.file.meta.Inode
-
- getMode() - Method in interface alluxio.master.file.meta.InodeView
-
- getMode() - Method in class alluxio.master.file.meta.MutableInode
-
- getMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional int32 mode = 4;
- getMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional int32 mode = 4;
- getMode() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional int32 mode = 4;
- getMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int32 mode = 10;
- getMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int32 mode = 10;
- getMode() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int32 mode = 10;
- getMode() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 mode = 16;
- getMode() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int32 mode = 16;
- getMode() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int32 mode = 16;
- getMode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int32 mode = 11;
- getMode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int32 mode = 11;
- getMode() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int32 mode = 11;
- getMode() - Method in class alluxio.security.authorization.AccessControlList
-
- getMode() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
-
- getMode() - Method in class alluxio.underfs.options.CreateOptions
-
- getMode() - Method in class alluxio.underfs.options.MkdirsOptions
-
- getMode() - Method in class alluxio.underfs.UfsStatus
-
Gets the mode of the given path in short format, e.g 0700.
- getMode() - Method in class alluxio.util.webui.UIFileInfo
-
Gets mode.
- getMode() - Method in class alluxio.wire.FileInfo
-
- getModeBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- getModeBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- getModeBuilder() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 5;
- getModeOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- getModeOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.PMode mode = 3;
- getModeOrBuilder() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.PMode mode = 3;
- getModeOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- getModeOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.PMode mode = 3;
- getModeOrBuilder() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.PMode mode = 3;
- getModeOrBuilder() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 5;
- getModeOrBuilder() - Method in class alluxio.grpc.SetAttributePOptions
-
optional .alluxio.grpc.PMode mode = 5;
- getModeOrBuilder() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional .alluxio.grpc.PMode mode = 5;
- getModificationTime() - Method in class alluxio.util.webui.UIFileInfo
-
Gets modification time.
- getModTimeTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting modification time.
- getMostSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
-
optional int64 mostSignificantBits = 1;
- getMostSignificantBits() - Method in class alluxio.grpc.FsOpPId
-
optional int64 mostSignificantBits = 1;
- getMostSignificantBits() - Method in interface alluxio.grpc.FsOpPIdOrBuilder
-
optional int64 mostSignificantBits = 1;
- getMostSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
optional int64 mostSignificantBits = 1;
- getMostSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId
-
optional int64 mostSignificantBits = 1;
- getMostSignificantBits() - Method in interface alluxio.proto.journal.Journal.JournalOpPIdOrBuilder
-
optional int64 mostSignificantBits = 1;
- getMountedRootPath(AlluxioConfiguration, FuseOptions) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Gets the path be mounted to local fuse mount point.
- getMountId(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Reverse resolve a ufs uri and get mount id.
- getMountId() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getMountId(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- getMountId() - Method in class alluxio.client.file.URIStatus
-
- getMountId() - Method in class alluxio.grpc.Block.Builder
-
optional int64 mountId = 5;
- getMountId() - Method in class alluxio.grpc.Block
-
optional int64 mountId = 5;
- getMountId() - Method in interface alluxio.grpc.BlockOrBuilder
-
optional int64 mountId = 5;
- getMountId() - Method in class alluxio.grpc.File.Builder
-
optional int64 mountId = 4;
- getMountId() - Method in class alluxio.grpc.File
-
optional int64 mountId = 4;
- getMountId() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 mountId = 23;
- getMountId() - Method in class alluxio.grpc.FileInfo
-
optional int64 mountId = 23;
- getMountId() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 mountId = 23;
- getMountId() - Method in interface alluxio.grpc.FileOrBuilder
-
optional int64 mountId = 4;
- getMountId(GetMountIdPRequest, StreamObserver<GetMountIdPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Reverse resolve a ufs path and get mount id.
- getMountId(GetMountIdPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Reverse resolve a ufs path and get mount id.
- getMountId(GetMountIdPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Reverse resolve a ufs path and get mount id.
- getMountId(GetMountIdPRequest, StreamObserver<GetMountIdPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Reverse resolve a ufs path and get mount id.
- getMountId(GetMountIdPRequest, StreamObserver<GetMountIdPResponse>) - Method in interface alluxio.grpc.FileSystemMasterWorkerServiceGrpc.AsyncService
-
Reverse resolve a ufs path and get mount id.
- getMountId(GetMountIdPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub
-
Reverse resolve a ufs path and get mount id.
- getMountId(GetMountIdPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub
-
Reverse resolve a ufs path and get mount id.
- getMountId(GetMountIdPRequest, StreamObserver<GetMountIdPResponse>) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub
-
Reverse resolve a ufs path and get mount id.
- getMountId() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
required int64 mountId = 1;
- getMountId() - Method in class alluxio.grpc.GetMountIdPResponse
-
required int64 mountId = 1;
- getMountId() - Method in interface alluxio.grpc.GetMountIdPResponseOrBuilder
-
required int64 mountId = 1;
- getMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
the id of the ufs
- getMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest
-
the id of the ufs
- getMountId() - Method in interface alluxio.grpc.GetUfsInfoPRequestOrBuilder
-
the id of the ufs
- getMountId() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 mountId = 8;
- getMountId() - Method in class alluxio.grpc.MountPointInfo
-
optional int64 mountId = 8;
- getMountId() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional int64 mountId = 8;
- getMountId() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
-
- getMountId() - Method in class alluxio.job.plan.persist.PersistConfig
-
- getMountId(GetMountIdPRequest, StreamObserver<GetMountIdPResponse>) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
-
- getMountId() - Method in class alluxio.master.file.meta.MountTable.Resolution
-
- getMountId() - Method in class alluxio.master.file.meta.options.MountInfo
-
- getMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional int64 mount_id = 5;
- getMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional int64 mount_id = 5;
- getMountId() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional int64 mount_id = 5;
- getMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional int64 mountId = 5;
- getMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
optional int64 mountId = 5;
- getMountId() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
optional int64 mountId = 5;
- getMountId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
optional int64 mount_id = 1;
- getMountId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
optional int64 mount_id = 1;
- getMountId() - Method in interface alluxio.proto.journal.File.ActiveSyncTxIdEntryOrBuilder
-
optional int64 mount_id = 1;
- getMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional int64 mount_id = 6;
- getMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional int64 mount_id = 6;
- getMountId() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional int64 mount_id = 6;
- getMountId() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
optional int64 mount_id = 2;
- getMountId() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
-
optional int64 mount_id = 2;
- getMountId() - Method in interface alluxio.proto.journal.File.AddSyncPointEntryOrBuilder
-
optional int64 mount_id = 2;
- getMountId() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
optional int64 mount_id = 2;
- getMountId() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
optional int64 mount_id = 2;
- getMountId() - Method in interface alluxio.proto.journal.File.RemoveSyncPointEntryOrBuilder
-
optional int64 mount_id = 2;
- getMountId() - Method in class alluxio.wire.FileInfo
-
- getMountId() - Method in class alluxio.wire.MountPointInfo
-
- getMountId(String) - Method in class alluxio.worker.file.FileSystemMasterClient
-
Reverse resolve a ufs uri and get mount id.
- getMountIdFromUfsPath(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getMountIdFromUfsPath(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
-
Returns the mount id according to the ufs path.
- GetMountIdPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetMountIdPRequest
- GetMountIdPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetMountIdPRequest
- GetMountIdPRequestOrBuilder - Interface in alluxio.grpc
-
- GetMountIdPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetMountIdPResponse
- GetMountIdPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetMountIdPResponse
- GetMountIdPResponseOrBuilder - Interface in alluxio.grpc
-
- getMountInfo(long) - Method in class alluxio.master.file.meta.MountTable
-
- getMountInfo(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
-
Gets mount information for the path.
- getMountInfo() - Method in class alluxio.master.file.meta.MountTable.ReverseResolution
-
- getMountMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getMountOptions() - Method in class alluxio.fuse.options.FuseCliOptions
-
- getMountOptions() - Method in class alluxio.fuse.options.MountCliOptions
-
- getMountOptions() - Method in class alluxio.wire.UfsInfo
-
- getMountPath() - Method in class alluxio.wire.JournalDiskInfo
-
- getMountPoint() - Method in class alluxio.fuse.options.FuseCliOptions
-
- getMountPoint() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool mountPoint = 20;
- getMountPoint() - Method in class alluxio.grpc.FileInfo
-
optional bool mountPoint = 20;
- getMountPoint() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool mountPoint = 20;
- getMountPoint(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
-
Returns the closest ancestor mount point the given path is nested under.
- getMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool mount_point = 11;
- getMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional bool mount_point = 11;
- getMountPoint() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional bool mount_point = 11;
- getMountPoint() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional bool mount_point = 2;
- getMountPoint() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
optional bool mount_point = 2;
- getMountPoint() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
-
optional bool mount_point = 2;
- getMountPoint() - Method in class alluxio.util.UnixMountInfo
-
- getMountPoint() - Method in class alluxio.util.webui.UIMountPointInfo
-
Gets mount point.
- getMountPointInfos() - Method in class alluxio.wire.MasterWebUIMountTable
-
Get mount point infos [ ].
- getMountPointInfoSummary(boolean) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getMountPointInfoSummary() - Method in interface alluxio.master.file.FileSystemMaster
-
- getMountPointInfoSummary(boolean) - Method in interface alluxio.master.file.FileSystemMaster
-
- getMountPoints() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
Deprecated.
- getMountPoints() - Method in class alluxio.grpc.GetMountTablePResponse
-
Deprecated.
- getMountPoints() - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
-
Deprecated.
- getMountPoints() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getMountPointsCount() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- getMountPointsCount() - Method in class alluxio.grpc.GetMountTablePResponse
-
- getMountPointsCount() - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- getMountPointsMap() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- getMountPointsMap() - Method in class alluxio.grpc.GetMountTablePResponse
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- getMountPointsMap() - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- getMountPointsOrDefault(String, MountPointInfo) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- getMountPointsOrDefault(String, MountPointInfo) - Method in class alluxio.grpc.GetMountTablePResponse
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- getMountPointsOrDefault(String, MountPointInfo) - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- getMountPointsOrThrow(String) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- getMountPointsOrThrow(String) - Method in class alluxio.grpc.GetMountTablePResponse
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- getMountPointsOrThrow(String) - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- getMountSpecificConf() - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getMountTable(boolean) - Method in class alluxio.client.file.DelegatingFileSystem
-
- getMountTable() - Method in interface alluxio.client.file.FileSystem
-
Lists all mount points and their corresponding under storage addresses.
- getMountTable(boolean) - Method in interface alluxio.client.file.FileSystem
-
Lists all mount points and their corresponding under storage addresses.
- getMountTable(boolean) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- getMountTable() - Method in interface alluxio.client.file.FileSystemMasterClient
-
Lists all mount points and their corresponding under storage addresses.
- getMountTable(boolean) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Lists all mount points and their corresponding under storage addresses.
- getMountTable(boolean) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- getMountTable(boolean) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- getMountTable(GetMountTablePRequest, StreamObserver<GetMountTablePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Returns a map from each Alluxio path to information of corresponding mount point
- getMountTable(GetMountTablePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Returns a map from each Alluxio path to information of corresponding mount point
- getMountTable(GetMountTablePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Returns a map from each Alluxio path to information of corresponding mount point
- getMountTable(GetMountTablePRequest, StreamObserver<GetMountTablePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Returns a map from each Alluxio path to information of corresponding mount point
- getMountTable() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getMountTable(GetMountTablePRequest, StreamObserver<GetMountTablePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- getMountTable() - Method in class alluxio.master.file.meta.MountTable
-
Returns a copy of the current mount table, the mount table is a map from Alluxio file system
URIs to the corresponding mount point information.
- getMountTable() - Method in class alluxio.master.file.meta.MountTable.State
-
- GetMountTablePRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetMountTablePRequest
- GetMountTablePRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetMountTablePRequest
- GetMountTablePRequestOrBuilder - Interface in alluxio.grpc
-
- GetMountTablePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetMountTablePResponse
- GetMountTablePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetMountTablePResponse
- GetMountTablePResponseOrBuilder - Interface in alluxio.grpc
-
- getMoveBlockMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getMoveJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- getMoveJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- getMoveJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- getMoveJobBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- getMoveJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- getMoveJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- getMoveJobOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- getMoveMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getMs(String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
-
Converts the input time into millisecond unit.
- getMs(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the time of key in millisecond unit.
- getMs(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the time of key in millisecond unit.
- getMs(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getMs(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getMsArg(CommandLine, Option, long) - Static method in class alluxio.cli.fs.FileSystemShellUtils
-
Gets the value of an option from the command line.
- getMsg() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
optional string msg = 1;
- getMsg() - Method in class alluxio.grpc.TransferLeaderMessage
-
optional string msg = 1;
- getMsg() - Method in interface alluxio.grpc.TransferLeaderMessageOrBuilder
-
optional string msg = 1;
- getMsgBytes() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
optional string msg = 1;
- getMsgBytes() - Method in class alluxio.grpc.TransferLeaderMessage
-
optional string msg = 1;
- getMsgBytes() - Method in interface alluxio.grpc.TransferLeaderMessageOrBuilder
-
optional string msg = 1;
- getMultipartMetaFilepathForUploadId(String) - Static method in class alluxio.proxy.s3.S3RestUtils
-
- getMultipartTemporaryDirForObject(String, String, String) - Static method in class alluxio.proxy.s3.S3RestUtils
-
- getMultipartUploadEnabled() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getMultiple(String, int) - Method in class alluxio.client.file.dora.ConsistentHashProvider
-
Finds multiple workers from the hash ring.
- getMultipleDataFileChannel(Channel, long) - Method in class alluxio.worker.dora.PagedFileReader
-
- getMutable(long, ReadOption) - Method in class alluxio.master.metastore.caching.CachingInodeStore
-
- getMutable(long, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
-
- getMutable(long, ReadOption) - Method in interface alluxio.master.metastore.InodeStore
-
Gets a mutable representation of the specified inode.
- getMutable(long) - Method in interface alluxio.master.metastore.InodeStore
-
- getMutable(long, ReadOption) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- getMutableAddedBlocksOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
Deprecated.
- getMutableCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
Deprecated.
- getMutableCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
Deprecated.
- getMutableCapacityBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
-
Deprecated.
- getMutableColumn() - Method in class alluxio.grpc.table.FileStatistics.Builder
-
Deprecated.
- getMutableColumnConstraints() - Method in class alluxio.grpc.table.Constraint.Builder
-
Deprecated.
- getMutableCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
Deprecated.
- getMutableErrors() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Deprecated.
- getMutableErrors() - Method in class alluxio.grpc.PolicyStatus.Builder
-
Deprecated.
- getMutableLostStorage() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
Deprecated.
- getMutableLostStorage() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
Deprecated.
- getMutableLostStorage() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
Deprecated.
- getMutableMetrics() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
Deprecated.
- getMutableMountPoints() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
Deprecated.
- getMutableOptions() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
Deprecated.
- getMutableParameter() - Method in class alluxio.grpc.table.Database.Builder
-
Deprecated.
- getMutableParameters() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
Deprecated.
- getMutableParameters() - Method in class alluxio.grpc.table.TableInfo.Builder
-
Deprecated.
- getMutablePartitionStatistics() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
Deprecated.
- getMutablePathConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
Deprecated.
- getMutableProperties() - Method in class alluxio.grpc.MountPointInfo.Builder
-
Deprecated.
- getMutableProperties() - Method in class alluxio.grpc.MountPOptions.Builder
-
Deprecated.
- getMutableProperties() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
Deprecated.
- getMutableProperties() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
Deprecated.
- getMutableProperties() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
Deprecated.
- getMutableSerdelibParameters() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
Deprecated.
- getMutableSerdeParameters() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
Deprecated.
- getMutableStats() - Method in class alluxio.grpc.table.Layout.Builder
-
Deprecated.
- getMutableStatus() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
Deprecated.
- getMutableTablesErrors() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
Deprecated.
- getMutableTags() - Method in class alluxio.grpc.Metric.Builder
-
Deprecated.
- getMutableTotalBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
Deprecated.
- getMutableUsedBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
Deprecated.
- getMutableUsedBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
Deprecated.
- getMutableUsedBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
Deprecated.
- getMutableUsedBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
-
Deprecated.
- getMutableValues() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
Deprecated.
- getMutableWarns() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Deprecated.
- getMutableXattr() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
Deprecated.
- getMutableXattr() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
Deprecated.
- getMutableXattr() - Method in class alluxio.grpc.FileInfo.Builder
-
Deprecated.
- getMutableXattr() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
Deprecated.
- getMutableXattr() - Method in class alluxio.grpc.UfsStatus.Builder
-
Deprecated.
- getMutableXAttr() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
Deprecated.
- getMutableXAttr() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
Deprecated.
- getMutableXAttr() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
Deprecated.
- getMutableXAttr() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
Deprecated.
- getMyRunningWorker() - Method in class alluxio.scheduler.job.Task
-
Get the worker info this task runs on.
- getName() - Method in class alluxio.AlluxioURI
-
- getName() - Method in class alluxio.cli.ClusterConfConsistencyValidationTask
-
- getName() - Method in class alluxio.cli.hdfs.HdfsConfParityValidationTask
-
- getName() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
-
- getName() - Method in class alluxio.cli.hdfs.HdfsProxyUserValidationTask
-
- getName() - Method in class alluxio.cli.hdfs.HdfsVersionValidationTask
-
- getName() - Method in class alluxio.cli.hdfs.SecureHdfsValidationTask
-
- getName() - Method in class alluxio.cli.hms.CreateHmsClientValidationTask
-
- getName() - Method in class alluxio.cli.hms.DatabaseValidationTask
-
- getName() - Method in class alluxio.cli.hms.TableValidationTask
-
- getName() - Method in class alluxio.cli.hms.UriCheckTask
-
- getName() - Method in class alluxio.cli.NativeLibValidationTask
-
- getName() - Method in class alluxio.cli.PortAvailabilityValidationTask
-
- getName() - Method in class alluxio.cli.RamDiskMountPrivilegeValidationTask
-
- getName() - Method in class alluxio.cli.SshValidationTask
-
- getName() - Method in class alluxio.cli.StorageSpaceValidationTask
-
- getName() - Method in class alluxio.cli.UfsDirectoryValidationTask
-
- getName() - Method in class alluxio.cli.UfsSuperUserValidationTask
-
- getName() - Method in class alluxio.cli.UfsVersionValidationTask
-
- getName() - Method in class alluxio.cli.UserLimitValidationTask
-
- getName() - Method in interface alluxio.cli.ValidationTask
-
Gets the name of the task.
- getName() - Method in class alluxio.cli.ValidationTaskResult
-
- getName() - Method in class alluxio.client.file.URIStatus
-
For example for the uri: alluxio://host:1000/foo/bar/baz, baz is the name.
- getName() - Method in class alluxio.conf.PropertyKey
-
- getName() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string name = 1;
- getName() - Method in class alluxio.grpc.ConfigProperty
-
optional string name = 1;
- getName() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
-
optional string name = 1;
- getName() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string name = 2;
- getName() - Method in class alluxio.grpc.FileInfo
-
optional string name = 2;
- getName() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string name = 2;
- getName() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
optional string name = 1;
- getName() - Method in class alluxio.grpc.InconsistentProperty
-
optional string name = 1;
- getName() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
-
optional string name = 1;
- getName() - Method in class alluxio.grpc.JobInfo.Builder
-
Some jobs don't have these
- getName() - Method in class alluxio.grpc.JobInfo
-
Some jobs don't have these
- getName() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
Some jobs don't have these
- getName() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional string name = 2;
- getName() - Method in class alluxio.grpc.ListAllPOptions
-
optional string name = 2;
- getName() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
-
optional string name = 2;
- getName() - Method in class alluxio.grpc.Metric.Builder
-
optional string name = 3;
- getName() - Method in class alluxio.grpc.Metric
-
optional string name = 3;
- getName() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional string name = 3;
- getName() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional string name = 2;
- getName() - Method in class alluxio.grpc.PolicyInfo
-
optional string name = 2;
- getName() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
-
optional string name = 2;
- getName() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string name = 2;
- getName() - Method in class alluxio.grpc.table.FieldSchema
-
optional string name = 2;
- getName() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional string name = 2;
- getName() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string name = 1;
- getName() - Method in class alluxio.grpc.UfsStatus
-
optional string name = 1;
- getName() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string name = 1;
- getName() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
-
- getName() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
-
- getName() - Method in interface alluxio.job.CmdConfig
-
- getName() - Method in interface alluxio.job.JobConfig
-
- getName() - Method in class alluxio.job.plan.BatchedJobConfig
-
- getName() - Method in class alluxio.job.plan.migrate.MigrateConfig
-
- getName() - Method in class alluxio.job.plan.NoopPlanConfig
-
- getName() - Method in class alluxio.job.plan.persist.PersistConfig
-
- getName() - Method in class alluxio.job.plan.replicate.MoveConfig
-
- getName() - Method in interface alluxio.job.wire.JobInfo
-
- getName() - Method in class alluxio.job.wire.PlanInfo
-
- getName() - Method in class alluxio.job.wire.TaskInfo
-
- getName() - Method in class alluxio.job.wire.WorkflowInfo
-
- getName() - Method in class alluxio.job.workflow.composite.CompositeConfig
-
- getName() - Method in class alluxio.job.workflow.composite.CompositeExecution
-
- getName() - Method in class alluxio.job.workflow.WorkflowExecution
-
- getName() - Method in class alluxio.master.block.BlockMasterFactory
-
- getName() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getName() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getName() - Method in class alluxio.master.file.FileSystemMasterFactory
-
- getName() - Method in class alluxio.master.file.meta.Edge
-
- getName() - Method in class alluxio.master.file.meta.Inode
-
- getName() - Method in interface alluxio.master.file.meta.InodeView
-
- getName() - Method in class alluxio.master.file.meta.MutableInode
-
- getName() - Method in class alluxio.master.file.meta.xattr.AbstractExtendedAttribute
-
- getName() - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
-
- getName() - Method in class alluxio.master.job.JobMaster
-
- getName() - Method in class alluxio.master.journal.checkpoint.CompoundCheckpointFormat.CompoundCheckpointReader.Entry
-
- getName() - Method in class alluxio.master.journal.DefaultJournalMaster
-
- getName() - Method in class alluxio.master.journal.JournalMasterFactory
-
- getName() - Method in class alluxio.master.journal.ufs.UfsJournalMultiMasterPrimarySelector
-
- getName() - Method in interface alluxio.master.MasterFactory
-
- getName() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getName() - Method in class alluxio.master.meta.MetaMasterFactory
-
- getName() - Method in class alluxio.master.metrics.DefaultMetricsMaster
-
- getName() - Method in class alluxio.master.metrics.MetricsMasterFactory
-
- getName() - Method in class alluxio.master.NoopMaster
-
- getName() - Method in class alluxio.metrics.Metric
-
- getName() - Method in class alluxio.metrics.MetricKey
-
- getName() - Method in interface alluxio.metrics.MetricsAggregator
-
- getName() - Method in class alluxio.metrics.MetricsFilter
-
- getName() - Method in class alluxio.metrics.source.JvmSource
-
- getName() - Method in interface alluxio.metrics.source.Source
-
Gets the name of the Source.
- getName() - Method in class alluxio.metrics.TimeSeries
-
- getName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string name = 3;
- getName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string name = 3;
- getName() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string name = 3;
- getName() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string name = 3;
- getName() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string name = 3;
- getName() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string name = 3;
- getName() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string name = 3;
- getName() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string name = 3;
- getName() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string name = 3;
- getName() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string name = 1;
- getName() - Method in class alluxio.proto.journal.Job.FileFilter
-
required string name = 1;
- getName() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
-
required string name = 1;
- getName() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional string name = 2;
- getName() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
optional string name = 2;
- getName() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
-
optional string name = 2;
- getName() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
optional string name = 1;
- getName() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
-
optional string name = 1;
- getName() - Method in interface alluxio.proto.journal.Policy.PolicyRemoveEntryOrBuilder
-
optional string name = 1;
- getName() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string name = 6;
- getName() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string name = 6;
- getName() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string name = 6;
- getName() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional string name = 1;
- getName() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
optional string name = 1;
- getName() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
-
optional string name = 1;
- getName() - Method in class alluxio.s3.ListAllMyBucketsResult.Bucket
-
- getName() - Method in class alluxio.s3.ListBucketResult
-
- getName() - Method in class alluxio.security.CurrentUser
-
- getName() - Method in class alluxio.security.User
-
- getName() - Method in interface alluxio.Server
-
- getName() - Method in class alluxio.stress.job.StressBenchConfig
-
- getName() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
-
Gets the name of the object.
- getName() - Method in class alluxio.underfs.UfsStatus
-
- getName() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
-
- getName() - Method in class alluxio.util.logging.SamplingLogger
-
- getName() - Method in class alluxio.util.webui.UIFileInfo
-
Gets name.
- getName() - Method in class alluxio.wire.FileInfo
-
- getName() - Method in class alluxio.wire.InconsistentProperty
-
- getName() - Method in class alluxio.wire.Property
-
- getName() - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getName() - Method in class alluxio.worker.http.ResponseFileInfo
-
Get the name of the file.
- getName() - Method in class alluxio.worker.JobWorker
-
- getNameBytes() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string name = 1;
- getNameBytes() - Method in class alluxio.grpc.ConfigProperty
-
optional string name = 1;
- getNameBytes() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
-
optional string name = 1;
- getNameBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string name = 2;
- getNameBytes() - Method in class alluxio.grpc.FileInfo
-
optional string name = 2;
- getNameBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string name = 2;
- getNameBytes() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
optional string name = 1;
- getNameBytes() - Method in class alluxio.grpc.InconsistentProperty
-
optional string name = 1;
- getNameBytes() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
-
optional string name = 1;
- getNameBytes() - Method in class alluxio.grpc.JobInfo.Builder
-
Some jobs don't have these
- getNameBytes() - Method in class alluxio.grpc.JobInfo
-
Some jobs don't have these
- getNameBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
Some jobs don't have these
- getNameBytes() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional string name = 2;
- getNameBytes() - Method in class alluxio.grpc.ListAllPOptions
-
optional string name = 2;
- getNameBytes() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
-
optional string name = 2;
- getNameBytes() - Method in class alluxio.grpc.Metric.Builder
-
optional string name = 3;
- getNameBytes() - Method in class alluxio.grpc.Metric
-
optional string name = 3;
- getNameBytes() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional string name = 3;
- getNameBytes() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional string name = 2;
- getNameBytes() - Method in class alluxio.grpc.PolicyInfo
-
optional string name = 2;
- getNameBytes() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
-
optional string name = 2;
- getNameBytes() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string name = 2;
- getNameBytes() - Method in class alluxio.grpc.table.FieldSchema
-
optional string name = 2;
- getNameBytes() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional string name = 2;
- getNameBytes() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string name = 1;
- getNameBytes() - Method in class alluxio.grpc.UfsStatus
-
optional string name = 1;
- getNameBytes() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string name = 1;
- getNameBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string name = 3;
- getNameBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string name = 3;
- getNameBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string name = 3;
- getNameBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string name = 3;
- getNameBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string name = 3;
- getNameBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string name = 3;
- getNameBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string name = 3;
- getNameBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string name = 3;
- getNameBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string name = 3;
- getNameBytes() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string name = 1;
- getNameBytes() - Method in class alluxio.proto.journal.Job.FileFilter
-
required string name = 1;
- getNameBytes() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional string name = 2;
- getNameBytes() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
optional string name = 2;
- getNameBytes() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
-
optional string name = 2;
- getNameBytes() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
optional string name = 1;
- getNameBytes() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
-
optional string name = 1;
- getNameBytes() - Method in interface alluxio.proto.journal.Policy.PolicyRemoveEntryOrBuilder
-
optional string name = 1;
- getNameBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string name = 6;
- getNameBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string name = 6;
- getNameBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string name = 6;
- getNameBytes() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional string name = 1;
- getNameBytes() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
optional string name = 1;
- getNameBytes() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
-
optional string name = 1;
- getNamedGroup(String) - Method in class alluxio.security.authorization.ExtendedACLEntries
-
- getNamedGroupActions() - Method in class alluxio.security.authorization.ExtendedACLEntries
-
- getNamedGroupsProto(ExtendedACLEntries) - Static method in class alluxio.util.proto.ProtoUtils
-
- getNamedUser(String) - Method in class alluxio.security.authorization.ExtendedACLEntries
-
- getNamedUserActions() - Method in class alluxio.security.authorization.ExtendedACLEntries
-
- getNamedUsersProto(ExtendedACLEntries) - Static method in class alluxio.util.proto.ProtoUtils
-
- getNamespace() - Method in class alluxio.master.file.meta.xattr.AbstractExtendedAttribute
-
- getNamespace() - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
-
- getNeedsSyncMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getNegotiatedProperty(String) - Method in class alluxio.security.authentication.plain.PlainSaslServer
-
- getNestedProperties(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets a set of properties that share a given common prefix key as a map.
- getNestedProperties(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets a set of properties that share a given common prefix key as a map.
- getNestedProperties(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getNestedProperties(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getNetAddress() - Method in class alluxio.client.block.BlockWorkerInfo
-
- getNettyChannelPools() - Method in class alluxio.client.file.FileSystemContext
-
- getNettyClientStateMachine() - Method in class alluxio.client.file.dora.netty.event.ResponseEventContext
-
Get the NettyClientStateMachine.
- getNettyDataLocalPort() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getNettyDataLocalPort() - Method in interface alluxio.worker.WorkerProcess
-
- getNettyDataPort() - Method in class alluxio.wire.WorkerNetAddress
-
- getNettyOutput() - Method in class alluxio.grpc.ReadableDataBuffer
-
- getNettyOutput() - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
-
- getNettyOutput() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
-
Returns an object for writing to a netty channel.
- getNettyOutput() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
-
- getNettyOutput() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
-
- getNettyOutput() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
-
- getNetworkGroup() - Method in class alluxio.grpc.GrpcChannelBuilder
-
- getNetworkGroup() - Method in class alluxio.grpc.GrpcChannelKey
-
- getNewBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- getNewBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- getNewBlock() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- getNewBlockBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- getNewBlockId() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getNewBlockIdForFile(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
-
- getNewBlockIdForFile(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- getNewBlockIdForFile(GetNewBlockIdForFilePRequest, StreamObserver<GetNewBlockIdForFilePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Generates a new block id for the given file.
- getNewBlockIdForFile(GetNewBlockIdForFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Generates a new block id for the given file.
- getNewBlockIdForFile(GetNewBlockIdForFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Generates a new block id for the given file.
- getNewBlockIdForFile(GetNewBlockIdForFilePRequest, StreamObserver<GetNewBlockIdForFilePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Generates a new block id for the given file.
- getNewBlockIdForFile(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getNewBlockIdForFile(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
-
Gets a new block id for the next block of a given file to write to.
- getNewBlockIdForFile(GetNewBlockIdForFilePRequest, StreamObserver<GetNewBlockIdForFilePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- GetNewBlockIdForFilePOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePOptions
- GetNewBlockIdForFilePOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePOptions
- GetNewBlockIdForFilePOptionsOrBuilder - Interface in alluxio.grpc
-
- GetNewBlockIdForFilePRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePRequest
- GetNewBlockIdForFilePRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePRequest
- GetNewBlockIdForFilePRequestOrBuilder - Interface in alluxio.grpc
-
- GetNewBlockIdForFilePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePResponse
- GetNewBlockIdForFilePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePResponse
- GetNewBlockIdForFilePResponseOrBuilder - Interface in alluxio.grpc
-
- getNewBlockOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- getNewBlockOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- getNewBlockOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- getNewContainerId() - Method in class alluxio.master.block.BlockContainerIdGenerator
-
- getNewContainerId() - Method in interface alluxio.master.block.ContainerIdGenerable
-
- getNewContainerId() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getNewerVersionAvailable() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getNewerVersionAvailable() - Method in interface alluxio.master.meta.MetaMaster
-
- getNewerVersionAvailable() - Method in class alluxio.wire.MasterWebUIInit
-
Gets newer version available.
- getNewJobId() - Method in class alluxio.job.meta.JobIdGenerator
-
- getNewJobId() - Method in class alluxio.master.job.JobMaster
-
- getNewName() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_name = 5;
- getNewName() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional string new_name = 5;
- getNewName() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional string new_name = 5;
- getNewNameBytes() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_name = 5;
- getNewNameBytes() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional string new_name = 5;
- getNewNameBytes() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional string new_name = 5;
- getNewParentId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 new_parent_id = 4;
- getNewParentId() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional int64 new_parent_id = 4;
- getNewParentId() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional int64 new_parent_id = 4;
- getNewPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_path = 7;
- getNewPath() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional string new_path = 7;
- getNewPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional string new_path = 7;
- getNewPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_path = 7;
- getNewPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional string new_path = 7;
- getNewPathBytes() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional string new_path = 7;
- getNextBatchBlocks(int) - Method in class alluxio.master.job.LoadJob
-
Get next batch of blocks.
- getNextChunk() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
-
Gets next chunk of object listings.
- getNextChunk() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunk
-
- getNextChunk() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunkV1
-
- getNextContainerId() - Method in class alluxio.master.block.BlockContainerIdGenerator
-
- getNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
optional int64 next_container_id = 1;
- getNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
-
optional int64 next_container_id = 1;
- getNextContainerId() - Method in interface alluxio.proto.journal.Block.BlockContainerIdGeneratorEntryOrBuilder
-
optional int64 next_container_id = 1;
- getNextContinuationToken() - Method in class alluxio.s3.ListBucketResult
-
- getNextInputStream() - Method in interface alluxio.master.journalv0.JournalReader
-
- getNextInputStream() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
-
- getNextInterval(long, long) - Method in class alluxio.heartbeat.CronExpressionIntervalSupplier
-
- getNextInterval(long, long) - Method in class alluxio.heartbeat.FixedIntervalSupplier
-
- getNextInterval(long, long) - Method in interface alluxio.heartbeat.SleepIntervalSupplier
-
Gets the next interval for sleeping.
- getNextMarker() - Method in class alluxio.s3.ListBucketResult
-
- getNextRoutes(int) - Method in class alluxio.master.job.CopyJob
-
Get next batch of blocks.
- getNextRoutes(int) - Method in class alluxio.master.job.MoveJob
-
Get next batch of blocks.
- getNextSequenceNumber() - Method in interface alluxio.master.journal.JournalReader
-
Gets the the sequence number of the next journal log entry to read.
- getNextSequenceNumber() - Method in class alluxio.master.journal.options.JournalReaderOptions
-
- getNextSequenceNumber() - Method in class alluxio.master.journal.options.JournalWriterOptions
-
- getNextSequenceNumber() - Method in class alluxio.master.journal.ufs.UfsJournalCheckpointThread
-
- getNextSequenceNumber() - Method in class alluxio.master.journal.ufs.UfsJournalLogWriter
-
- getNextSequenceNumber() - Method in class alluxio.master.journal.ufs.UfsJournalReader
-
- getNextSequenceNumber() - Method in interface alluxio.master.journalv0.JournalWriter
-
- getNextSequenceNumber() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
-
- getNextSequenceNumberToCheckpoint() - Method in class alluxio.master.journal.ufs.UfsJournal
-
- getNextSequenceNumberToWrite() - Method in class alluxio.master.journal.raft.RaftJournalWriter
-
- getNextSequenceNumberToWrite() - Method in class alluxio.master.journal.ufs.UfsJournal
-
- getNextTasks(Collection<WorkerInfo>) - Method in class alluxio.master.job.CopyJob
-
get next load task.
- getNextTasks(Collection<WorkerInfo>) - Method in class alluxio.master.job.DoraLoadJob
-
- getNextTasks(Collection<WorkerInfo>) - Method in class alluxio.master.job.LoadJob
-
get next load task.
- getNextTasks(Collection<WorkerInfo>) - Method in class alluxio.master.job.MoveJob
-
get next move task.
- getNextTasks(Collection<WorkerInfo>) - Method in interface alluxio.scheduler.job.Job
-
- getNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
If set, do not try to cache the block locally when reading the data from the UFS.
- getNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
If set, do not try to cache the block locally when reading the data from the UFS.
- getNoCache() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
If set, do not try to cache the block locally when reading the data from the UFS.
- getNodeAddress() - Method in class alluxio.common.RpcPortHealthCheckClient
-
- getNodeLocalWorker() - Method in class alluxio.client.file.FileSystemContext
-
- getNodeResults() - Method in class alluxio.stress.common.GeneralBenchSummary
-
- getNodeState() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
optional .alluxio.grpc.journal.NodeState node_state = 1;
- getNodeState() - Method in class alluxio.grpc.GetNodeStatePResponse
-
optional .alluxio.grpc.journal.NodeState node_state = 1;
- getNodeState() - Method in interface alluxio.grpc.GetNodeStatePResponseOrBuilder
-
optional .alluxio.grpc.journal.NodeState node_state = 1;
- getNodeState(GetNodeStatePRequest, StreamObserver<GetNodeStatePResponse>) - Method in interface alluxio.grpc.JournalMasterClientServiceGrpc.AsyncService
-
Gets the state of the current node and returns whether it is primary or standby.
- getNodeState(GetNodeStatePRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub
-
Gets the state of the current node and returns whether it is primary or standby.
- getNodeState(GetNodeStatePRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub
-
Gets the state of the current node and returns whether it is primary or standby.
- getNodeState(GetNodeStatePRequest, StreamObserver<GetNodeStatePResponse>) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceStub
-
Gets the state of the current node and returns whether it is primary or standby.
- getNodeState() - Method in class alluxio.master.journal.DefaultJournalMaster
-
- getNodeState() - Method in interface alluxio.master.journal.JournalMaster
-
Gets the node state.
- getNodeState(GetNodeStatePRequest, StreamObserver<GetNodeStatePResponse>) - Method in class alluxio.master.journal.JournalMasterClientServiceHandler
-
- GetNodeStatePRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetNodeStatePRequest
- GetNodeStatePRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetNodeStatePRequest
- GetNodeStatePRequestOrBuilder - Interface in alluxio.grpc
-
- GetNodeStatePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetNodeStatePResponse
- GetNodeStatePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetNodeStatePResponse
- GetNodeStatePResponseOrBuilder - Interface in alluxio.grpc
-
- getNonExistingDirectoryStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting status of non-existent directory.
- getNonExistingFileStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting status of non-existent file.
- getNonExistingPathStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting status of non-existent path.
- getNormalNodeInfos() - Method in class alluxio.wire.MasterWebUIWorkers
-
Get normal node infos node info [ ].
- getNotifyWorkerIdMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
-
- getNow(T) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
Returns the result value (or throws any encountered exception) if completed, else returns the
given valueIfAbsent.
- getNTotalFile() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets n total file.
- getNTotalFile() - Method in class alluxio.wire.MasterWebUILogs
-
Gets n total file.
- getNTotalFile() - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Gets n total file.
- getNTotalFile() - Method in class alluxio.wire.WorkerWebUILogs
-
Gets n total file.
- getNumActiveTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 numActiveTasks = 6;
- getNumActiveTasks() - Method in class alluxio.grpc.JobWorkerHealth
-
optional int32 numActiveTasks = 6;
- getNumActiveTasks() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional int32 numActiveTasks = 6;
- getNumActiveTasks() - Method in class alluxio.job.wire.JobWorkerHealth
-
- getNumActiveTasks() - Method in class alluxio.worker.job.task.PausableThreadPoolExecutor
-
- getNumActiveTasks() - Method in class alluxio.worker.job.task.TaskExecutorManager
-
- getNumber() - Method in enum alluxio.grpc.BackupState
-
- getNumber() - Method in enum alluxio.grpc.Bits
-
- getNumber() - Method in enum alluxio.grpc.BlockMasterInfoField
-
- getNumber() - Method in enum alluxio.grpc.ChannelAuthenticationScheme
-
- getNumber() - Method in enum alluxio.grpc.CommandType
-
- getNumber() - Method in enum alluxio.grpc.ConfigStatus
-
- getNumber() - Method in enum alluxio.grpc.ErrorType
-
- getNumber() - Method in enum alluxio.grpc.JobMasterMetaCommand
-
- getNumber() - Method in enum alluxio.grpc.JobProgressReportFormat
-
- getNumber() - Method in enum alluxio.grpc.JobSource
-
- getNumber() - Method in enum alluxio.grpc.JobType
-
- getNumber() - Method in enum alluxio.grpc.JournalDomain
-
- getNumber() - Method in enum alluxio.grpc.ListStatusPartialPOptions.OffsetTypeCase
-
- getNumber() - Method in enum alluxio.grpc.LoadDescendantPType
-
- getNumber() - Method in enum alluxio.grpc.LoadMetadataPType
-
- getNumber() - Method in enum alluxio.grpc.MasterInfoField
-
- getNumber() - Method in enum alluxio.grpc.MetaCommand
-
- getNumber() - Method in enum alluxio.grpc.MetricType
-
- getNumber() - Method in enum alluxio.grpc.NodeState
-
- getNumber() - Method in enum alluxio.grpc.OperationType
-
- getNumber() - Method in enum alluxio.grpc.PAclAction
-
- getNumber() - Method in enum alluxio.grpc.PAclEntryType
-
- getNumber() - Method in enum alluxio.grpc.QuorumServerState
-
- getNumber() - Method in enum alluxio.grpc.ReadPType
-
- getNumber() - Method in enum alluxio.grpc.RequestType
-
- getNumber() - Method in enum alluxio.grpc.SaslMessageType
-
- getNumber() - Method in enum alluxio.grpc.Scope
-
- getNumber() - Method in enum alluxio.grpc.ServiceType
-
- getNumber() - Method in enum alluxio.grpc.SetAclAction
-
- getNumber() - Method in enum alluxio.grpc.Status
-
- getNumber() - Method in enum alluxio.grpc.SyncPointStatus
-
- getNumber() - Method in enum alluxio.grpc.table.ColumnStatisticsData.DataCase
-
- getNumber() - Method in enum alluxio.grpc.table.Domain.ValueSetCase
-
- getNumber() - Method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
-
- getNumber() - Method in enum alluxio.grpc.table.PrincipalType
-
- getNumber() - Method in enum alluxio.grpc.table.TableInfo.TableType
-
- getNumber() - Method in enum alluxio.grpc.table.Value.ValueCase
-
- getNumber() - Method in enum alluxio.grpc.TaskStatus
-
- getNumber() - Method in enum alluxio.grpc.TtlAction
-
- getNumber() - Method in enum alluxio.grpc.UfsPMode
-
- getNumber() - Method in enum alluxio.grpc.WorkerInfoField
-
- getNumber() - Method in enum alluxio.grpc.WorkerRange
-
- getNumber() - Method in enum alluxio.grpc.WritePType
-
- getNumber() - Method in enum alluxio.grpc.WriteRequest.ValueCase
-
- getNumber() - Method in enum alluxio.grpc.XAttrPropagationStrategy
-
- getNumber() - Method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
-
- getNumber() - Method in enum alluxio.proto.dataserver.Protocol.RequestType
-
- getNumber() - Method in enum alluxio.proto.journal.File.PSetAclAction
-
- getNumber() - Method in enum alluxio.proto.journal.File.PTtlAction
-
- getNumber() - Method in enum alluxio.proto.journal.File.UfsMode
-
- getNumber() - Method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
-
- getNumber() - Method in enum alluxio.proto.journal.Job.PJobState
-
- getNumber() - Method in enum alluxio.proto.shared.Acl.AclAction
-
- getNumber() - Method in enum alluxio.proto.shared.Acl.AclEntryType
-
- getNumber() - Method in enum alluxio.proto.status.Status.PStatus
-
- getNumberOfBlocks() - Method in interface alluxio.worker.block.BlockStoreMeta
-
Note: This is only available when blocks are included.
- getNumberOfBlocks() - Method in class alluxio.worker.block.BlockWorkerMetrics
-
- getNumberOfDependents() - Method in class alluxio.concurrent.jsr.CompletableFuture
-
Returns the estimated number of CompletableFutures whose completions are awaiting completion of
this CompletableFuture.
- getNumBuckets() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
- getNumBuckets() - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
-
- getNumBuckets() - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
-
- getNumBuckets() - Method in class alluxio.master.file.meta.TtlBucketList
-
- getNumBucketsPerSegment() - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
-
- getNumDistincts() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional int64 num_distincts = 4;
- getNumDistincts() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional int64 num_distincts = 4;
- getNumEvents() - Method in class alluxio.time.ExponentialTimer
-
- getNumFalses() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_falses = 2;
- getNumFalses() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
optional int64 num_falses = 2;
- getNumFalses() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
-
optional int64 num_falses = 2;
- getNumInodes() - Method in class alluxio.master.file.meta.TtlBucketList
-
- getNumLocks() - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
-
- getNumNulls() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional int64 num_nulls = 3;
- getNumNulls() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- getNumSector(String, String) - Static method in class alluxio.util.HFSUtils
-
Converts the memory size to number of sectors.
- getNumSinks() - Static method in class alluxio.metrics.MetricsSystem
-
- getNumSuccess() - Method in class alluxio.stress.cli.Benchmark.MethodStatistics
-
- getNumTagsPerBuckets() - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
-
- getNumTagsPerBuckets() - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
-
- getNumTrues() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_trues = 1;
- getNumTrues() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
optional int64 num_trues = 1;
- getNumTrues() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
-
optional int64 num_trues = 1;
- getObject() - Method in class alluxio.proxy.s3.S3Handler
-
Get the object name of this request.
- getObject() - Method in class alluxio.worker.s3.S3NettyHandler
-
Get the object name of this request.
- getObjectHeaderSize() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
-
Returns the fixed overhead of for any
Object
subclass in this JVM.
- getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- getObjectListingChunk(ListObjectsRequest) - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- getObjectListingChunk(String, String, String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- getObjectListingChunk(String, boolean, String, int) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Gets a (partial) object listing result for the given key.
- getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Gets a (partial) object listing result for the given key.
- getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- getObjectListingChunk(ListObjectsRequest) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- getObjectListingChunk(ListObjectsRequest) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getObjectListingChunk(String, boolean, String, int) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getObjectListingChunkForPath(String, boolean) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- getObjectListingChunkForPath(String, boolean, String, int) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Gets a (partial) object listing for the given path.
- getObjectMetadata(String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
-
Retrieves an object's metadata.
- getObjectName() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
-
- getObjectOrListParts(String, String, String, String, String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
-
Downloads an object or list parts of the object in multipart upload.
- getObjectPadding() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
-
Returns the quantum field size for a field owned by an object in this JVM.
- getObjectSize(Object) - Static method in class alluxio.util.ObjectSizeCalculator
-
Given an object, returns the total allocated size, in bytes, of the object
and all other objects reachable from it.
- getObjectSize(Object, Set<Class<?>>) - Static method in class alluxio.util.ObjectSizeCalculator
-
Given an object, returns the total allocated size, in bytes, of the object
and all other objects reachable from it.
- getObjectStatus(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- getObjectStatus(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- getObjectStatus(String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- getObjectStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Get metadata information about object.
- getObjectStatus(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- getObjectStatus(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- getObjectStatus(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getObjectStatuses() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
-
Returns objects in a pseudo-directory which may be a file or a directory.
- getObjectStatuses() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunk
-
- getObjectStatuses() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunkV1
-
- getObjectTaskResource() - Method in class alluxio.proxy.s3.S3ObjectTask
-
Concatenate bucket and object to make a full path.
- getObjectTaskResource() - Method in class alluxio.worker.s3.S3NettyObjectTask
-
Concatenate bucket and object to make a full path.
- getOffset() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional int64 offset = 2;
- getOffset() - Method in class alluxio.grpc.FileBlockInfo
-
optional int64 offset = 2;
- getOffset() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
optional int64 offset = 2;
- getOffset() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 offset = 2;
- getOffset() - Method in class alluxio.grpc.ReadRequest
-
optional int64 offset = 2;
- getOffset() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
optional int64 offset = 2;
- getOffset() - Method in class alluxio.grpc.SnapshotData.Builder
-
Deprecated.
- getOffset() - Method in class alluxio.grpc.SnapshotData
-
Deprecated.
- getOffset() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
Deprecated.
- getOffset() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional int64 offset = 3;
- getOffset() - Method in class alluxio.grpc.WriteRequestCommand
-
optional int64 offset = 3;
- getOffset() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional int64 offset = 3;
- getOffset() - Method in class alluxio.grpc.WriteResponse.Builder
-
optional int64 offset = 1;
- getOffset() - Method in class alluxio.grpc.WriteResponse
-
optional int64 offset = 1;
- getOffset() - Method in interface alluxio.grpc.WriteResponseOrBuilder
-
optional int64 offset = 1;
- getOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 offset = 2;
- getOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
optional int64 offset = 2;
- getOffset() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
optional int64 offset = 2;
- getOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional int64 offset = 3;
- getOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
optional int64 offset = 3;
- getOffset() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
optional int64 offset = 3;
- getOffset(long) - Method in class alluxio.s3.S3RangeSpec
-
Get real offset of object.
- getOffset() - Method in class alluxio.underfs.options.FileLocationOptions
-
- getOffset() - Method in class alluxio.underfs.options.OpenOptions
-
- getOffset() - Method in class alluxio.wire.FileBlockInfo
-
- getOffsetCount() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Only start listing items after this many items have been processed.
- getOffsetCount() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Only start listing items after this many items have been processed.
- getOffsetCount() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Only start listing items after this many items have been processed.
- getOffsetId() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Start listing after the given FileId, the FileId can be calculated from the
result of a previous listing's FileInfo or URIStatus results using the
getFileId method.
- getOffsetId() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Start listing after the given FileId, the FileId can be calculated from the
result of a previous listing's FileInfo or URIStatus results using the
getFileId method.
- getOffsetId() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Start listing after the given FileId, the FileId can be calculated from the
result of a previous listing's FileInfo or URIStatus results using the
getFileId method.
- getOffsetInFile() - Method in class alluxio.grpc.Block.Builder
-
The offset of the block in within ufs the file.
- getOffsetInFile() - Method in class alluxio.grpc.Block
-
The offset of the block in within ufs the file.
- getOffsetInFile() - Method in interface alluxio.grpc.BlockOrBuilder
-
The offset of the block in within ufs the file.
- getOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The offset of the block in within the file.
- getOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
The offset of the block in within the file.
- getOffsetInFile() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
The offset of the block in within the file.
- getOffsetReceived() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- getOffsetReceived() - Method in class alluxio.grpc.DownloadSnapshotPRequest
-
Deprecated.
- getOffsetReceived() - Method in interface alluxio.grpc.DownloadSnapshotPRequestOrBuilder
-
Deprecated.
- getOffsetReceived() - Method in class alluxio.grpc.ReadRequest.Builder
-
Read receipt
- getOffsetReceived() - Method in class alluxio.grpc.ReadRequest
-
Read receipt
- getOffsetReceived() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
Read receipt
- getOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- getOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse
-
Deprecated.
- getOffsetReceived() - Method in interface alluxio.grpc.UploadSnapshotPResponseOrBuilder
-
Deprecated.
- getOffsetTypeCase() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- getOffsetTypeCase() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
- getOffsetTypeCase() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
- getOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
If set, only reserve space for the block.
- getOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
If set, only reserve space for the block.
- getOnlyReserveSpace() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
-
If set, only reserve space for the block.
- getOnTierPercentages() - Method in class alluxio.util.webui.UIFileInfo
-
Gets on-tier percentages.
- getOpenAction(int) - Static method in class alluxio.fuse.AlluxioFuseOpenUtils
-
Gets Alluxio Fuse open action based on open flag.
- getOpenFileHandleContainer() - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getOpenOrCreateFlags() - Method in class alluxio.fuse.file.FuseFileEntry
-
- getOpenUfsBlockOptions(long) - Method in class alluxio.client.file.options.InStreamOptions
-
- getOpenUfsBlockOptions() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptions() - Method in class alluxio.grpc.AsyncCacheRequest
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptions() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptions() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptions() - Method in class alluxio.grpc.CacheRequest
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptions() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest.Builder
-
This is only set for UFS block read.
- getOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest
-
This is only set for UFS block read.
- getOpenUfsBlockOptions() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
This is only set for UFS block read.
- getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
This is only set for UFS block read.
- getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
This is only set for UFS block read.
- getOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
This is only set for UFS block read.
- getOpenUfsBlockOptions() - Method in class alluxio.wire.BlockReadRequest
-
- getOpenUfsBlockOptions() - Method in class alluxio.worker.netty.BlockReadRequest
-
- getOpenUfsBlockOptionsBuilder() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsBuilder() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsBuilder() - Method in class alluxio.grpc.ReadRequest.Builder
-
This is only set for UFS block read.
- getOpenUfsBlockOptionsBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
This is only set for UFS block read.
- getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.AsyncCacheRequest
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.CacheRequest
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.ReadRequest.Builder
-
This is only set for UFS block read.
- getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.ReadRequest
-
This is only set for UFS block read.
- getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
This is only set for UFS block read.
- getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
This is only set for UFS block read.
- getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
This is only set for UFS block read.
- getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
This is only set for UFS block read.
- getOperation() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string operation = 1;
- getOperation() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string operation = 1;
- getOperation() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string operation = 1;
- getOperationBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string operation = 1;
- getOperationBytes() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string operation = 1;
- getOperationBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string operation = 1;
- getOperationContext() - Method in class alluxio.master.file.RpcContext
-
- getOperationCount() - Method in class alluxio.wire.WorkerWebUIOperations
-
Gets the operation count.
- getOperationId() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- getOperationId() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- getOperationId() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- getOperationId() - Method in class alluxio.master.file.contexts.CompleteFileContext
-
- getOperationId() - Method in class alluxio.master.file.contexts.CreateDirectoryContext
-
- getOperationId() - Method in class alluxio.master.file.contexts.CreateFileContext
-
- getOperationId() - Method in class alluxio.master.file.contexts.DeleteContext
-
- getOperationId() - Method in class alluxio.master.file.contexts.OperationContext
-
Get embedded operation id, passed via proto options.
- getOperationId() - Method in class alluxio.master.file.contexts.RenameContext
-
- getOperationId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- getOperationId() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- getOperationId() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- getOperationIdBuilder() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- getOperationIdBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- getOperationIdOrBuilder() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- getOperationIdOrBuilder() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- getOperationIdOrBuilder() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- getOperationIdOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- getOperationIdOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- getOperationIdOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- getOperationMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets operation metrics.
- getOperationMetrics() - Method in class alluxio.wire.WorkerWebUIMetrics
-
Gets operation metrics.
- getOperationMode(Map<String, UfsMode>) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getOperationMode(Map<String, UfsMode>) - Method in class alluxio.underfs.BaseUnderFileSystem
-
- getOperationMode(Map<String, UfsMode>) - Method in interface alluxio.underfs.UnderFileSystem
-
- getOperationMode(Map<String, UfsMode>) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getOperationTimeMs() - Method in class alluxio.master.file.contexts.CompleteFileContext
-
- getOperationTimeMs() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getOperationTimeMs() - Method in class alluxio.master.file.contexts.RenameContext
-
- getOperationTimeMs() - Method in class alluxio.master.file.contexts.SetAttributeContext
-
- getOperationType() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
optional .alluxio.grpc.job.OperationType operationType = 3;
- getOperationType() - Method in class alluxio.grpc.CmdStatusBlock
-
optional .alluxio.grpc.job.OperationType operationType = 3;
- getOperationType() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
-
optional .alluxio.grpc.job.OperationType operationType = 3;
- getOperationType() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.OperationType operationType = 2;
- getOperationType() - Method in class alluxio.grpc.CmdSummary
-
optional .alluxio.grpc.job.OperationType operationType = 2;
- getOperationType() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional .alluxio.grpc.job.OperationType operationType = 2;
- getOperationType() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
-
- getOperationType() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
-
- getOperationType() - Method in interface alluxio.job.CmdConfig
-
- getOperationType() - Method in class alluxio.job.wire.CmdStatusBlock
-
Get OperationType.
- getOperationType() - Method in class alluxio.master.job.common.CmdInfo
-
Get operation type.
- getOpId() - Method in class alluxio.master.file.RpcContext
-
gets op id.
- getOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 op_time_ms = 4;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
optional int64 op_time_ms = 4;
- getOpTimeMs() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
optional int64 op_time_ms = 4;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional int64 op_time_ms = 3;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
optional int64 op_time_ms = 3;
- getOpTimeMs() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
optional int64 op_time_ms = 3;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 op_time_ms = 3;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
optional int64 op_time_ms = 3;
- getOpTimeMs() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
-
optional int64 op_time_ms = 3;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 op_time_ms = 3;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional int64 op_time_ms = 3;
- getOpTimeMs() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional int64 op_time_ms = 3;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional int64 op_time_ms = 2;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.SetAclEntry
-
optional int64 op_time_ms = 2;
- getOpTimeMs() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
optional int64 op_time_ms = 2;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 op_time_ms = 2;
- getOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int64 op_time_ms = 2;
- getOpTimeMs() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int64 op_time_ms = 2;
- getOptionList() - Method in class alluxio.cli.AbstractValidationTask
-
- getOptionList() - Method in class alluxio.cli.hdfs.HdfsConfParityValidationTask
-
- getOptionList() - Method in interface alluxio.cli.ValidationTask
-
- getOptionName() - Method in class alluxio.fuse.options.BaseValueConverter
-
- getOptions() - Method in interface alluxio.cli.Command
-
- getOptions() - Method in class alluxio.cli.fs.command.CheckCachedCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.ChgrpCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.ChmodCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.ChownCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.CpCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.FreeCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.HeadCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.LoadCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.LsCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.RmCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.StatCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.TailCommand
-
- getOptions() - Method in class alluxio.cli.fs.command.TestCommand
-
- getOptions() - Method in class alluxio.cli.fsadmin.command.BackupCommand
-
- getOptions() - Method in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand
-
- getOptions() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
-
- getOptions() - Method in class alluxio.cli.fsadmin.command.EnableWorkerCommand
-
- getOptions() - Method in class alluxio.cli.fsadmin.command.ReportCommand
-
- getOptions() - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
-
- getOptions() - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
-
- getOptions() - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
-
- getOptions() - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
-
- getOptions() - Method in class alluxio.client.file.options.InStreamOptions
-
- getOptions() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.AddPolicyPRequest
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.BackupPRequest
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- getOptions() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- getOptions() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- getOptions() - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CancelPRequest
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.CancelPRequestOrBuilder
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CheckAccessPRequest
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- getOptions() - Method in class alluxio.grpc.CommitBlockPRequest
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- getOptions() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- getOptions() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CompleteFilePRequest
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.CreateFilePRequest
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.DeletePRequest.Builder
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.DeletePRequest
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.ExistsPRequest
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- getOptions() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.FreePRequest.Builder
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.FreePRequest
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.FreePRequestOrBuilder
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- getOptions() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- getOptions() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- getOptions() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.GetAllMasterStatusPRequestOrBuilder
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.GetAllWorkerHealthPRequestOrBuilder
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetBlockInfoPRequest
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetBlockInfoPRequestOrBuilder
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetCmdStatusDetailedRequestOrBuilder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetCmdStatusRequest
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetCmdStatusRequestOrBuilder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetFileInfoPRequest
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetFileInfoPRequestOrBuilder
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetJobProgressPRequest
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.GetJobServiceSummaryPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetJobStatusDetailedPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetJobStatusPRequest
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetJobStatusPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetMasterIdPRequest
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.GetPinnedFileIdsPRequestOrBuilder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.GetQuorumInfoPRequestOrBuilder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- getOptions() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- getOptions() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- getOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.GetStateLockHoldersPRequestOrBuilder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetStatusPRequest
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetUfsInfoPRequestOrBuilder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- getOptions() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.JobMasterHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.ListAllPRequest.Builder
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.ListAllPRequest
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.ListAllPRequestOrBuilder
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.ListPolicyPRequest
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.ListPolicyPRequestOrBuilder
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.ListProxyStatusPRequest
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.ListProxyStatusPRequestOrBuilder
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.ListStatusPRequest
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptions() - Method in class alluxio.grpc.LoadFileRequest
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptions() - Method in class alluxio.grpc.LoadRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptions() - Method in class alluxio.grpc.LoadRequest
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.LoadRequestOrBuilder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptions() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.MasterHeartbeatPRequest
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.MasterHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.MetricsHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.MountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.MountPRequest
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptions() - Method in interface alluxio.grpc.MountPRequestOrBuilder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- getOptions() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptions() - Method in class alluxio.grpc.PolicyInfo
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptions() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptions() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.ProxyHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.RegisterJobMasterPRequest
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.RegisterJobMasterPRequestOrBuilder
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.RegisterMasterPRequest
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.RegisterMasterPRequestOrBuilder
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- getOptions() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- getOptions() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- getOptions() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- getOptions() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.RemovePolicyPRequest
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.RenamePRequest.Builder
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- getOptions() - Method in class alluxio.grpc.RenamePRequest
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- getOptions() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- getOptions() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.ResetPrioritiesPRequest
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.ResetPrioritiesPRequestOrBuilder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.RunPRequest.Builder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.RunPRequest
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.RunPRequestOrBuilder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the method options
- getOptions() - Method in class alluxio.grpc.SetAclPRequest
-
the method options
- getOptions() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the method options
- getOptions() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.SetAttributePRequest
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- getOptions() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- getOptions() - Method in class alluxio.grpc.SubmitRequest
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.SubmitRequestOrBuilder
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- getOptions() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
Deprecated.
- getOptions() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
Deprecated.
- getOptions() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
Deprecated.
- getOptions() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- getOptions() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- getOptions() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.UnmountPRequest
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- getOptions() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.UpdateMountPRequest
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptions() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- getOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- getOptions() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- getOptions() - Method in class alluxio.job.CopyJobRequest
-
- getOptions() - Method in class alluxio.job.LoadJobRequest
-
- getOptions() - Method in class alluxio.job.MoveJobRequest
-
- getOptions() - Method in class alluxio.master.file.contexts.OperationContext
-
- getOptions() - Method in class alluxio.master.file.meta.options.MountInfo
-
- getOptions() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptions() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptions() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptions() - Method in class alluxio.util.UnixMountInfo
-
- getOptions() - Method in class alluxio.worker.dora.OpenFileHandle
-
Get Alluxio create file options.
- getOptionsBuilder() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- getOptionsBuilder() - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- getOptionsBuilder() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.DeletePRequest.Builder
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- getOptionsBuilder() - Method in class alluxio.grpc.FreePRequest.Builder
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- getOptionsBuilder() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- getOptionsBuilder() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- getOptionsBuilder() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.ListAllPRequest.Builder
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.LoadRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.MountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptionsBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- getOptionsBuilder() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptionsBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- getOptionsBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- getOptionsBuilder() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.RenamePRequest.Builder
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- getOptionsBuilder() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.RunPRequest.Builder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the method options
- getOptionsBuilder() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- getOptionsBuilder() - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- getOptionsBuilder() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptionsBuilder() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- getOptionsBuilder() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptionsCount() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- getOptionsCount() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
- getOptionsCount() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
map<string, string> options = 5;
- getOptionsMap() - Method in class alluxio.fuse.options.MountCliOptions
-
- getOptionsMap() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
map<string, string> options = 5;
- getOptionsMap() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
map<string, string> options = 5;
- getOptionsMap() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
map<string, string> options = 5;
- getOptionsOrBuilder() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.AddPolicyPRequest
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.BackupPRequest
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- getOptionsOrBuilder() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CancelPRequest
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.CancelPRequestOrBuilder
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CheckAccessPRequest
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CommitBlockPRequest
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePRequest
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.CreateFilePRequest
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.DeletePRequest.Builder
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.DeletePRequest
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ExistsPRequest
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.FreePRequest.Builder
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.FreePRequest
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.FreePRequestOrBuilder
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetAllMasterStatusPRequestOrBuilder
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetAllWorkerHealthPRequestOrBuilder
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetBlockInfoPRequest
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetBlockInfoPRequestOrBuilder
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetCmdStatusDetailedRequestOrBuilder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetCmdStatusRequest
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetCmdStatusRequestOrBuilder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetFileInfoPRequest
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetFileInfoPRequestOrBuilder
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetJobServiceSummaryPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetJobStatusDetailedPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobStatusPRequest
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetJobStatusPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetPinnedFileIdsPRequestOrBuilder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetQuorumInfoPRequest
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetQuorumInfoPRequestOrBuilder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetStateLockHoldersPRequestOrBuilder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetStatusPRequest
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetUfsInfoPRequest
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetUfsInfoPRequestOrBuilder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.JobMasterHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListAllPRequest.Builder
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListAllPRequest
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.ListAllPRequestOrBuilder
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListPolicyPRequest
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.ListPolicyPRequestOrBuilder
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListProxyStatusPRequest
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.ListProxyStatusPRequestOrBuilder
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPRequest
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.LoadFileRequest
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.LoadRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.LoadRequest
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.LoadRequestOrBuilder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.MasterHeartbeatPRequest
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.MasterHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.MetricsHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.MountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.MountPRequest
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.MountPRequestOrBuilder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptionsOrBuilder() - Method in class alluxio.grpc.PolicyInfo
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.ProxyHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterJobMasterPRequest
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.RegisterJobMasterPRequestOrBuilder
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterMasterPRequest
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.RegisterMasterPRequestOrBuilder
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RemovePolicyPRequest
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RenamePRequest.Builder
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RenamePRequest
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ResetPrioritiesPRequest
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.ResetPrioritiesPRequestOrBuilder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RunPRequest.Builder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.RunPRequest
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.RunPRequestOrBuilder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the method options
- getOptionsOrBuilder() - Method in class alluxio.grpc.SetAclPRequest
-
the method options
- getOptionsOrBuilder() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the method options
- getOptionsOrBuilder() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.SetAttributePRequest
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.SubmitRequest
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.SubmitRequestOrBuilder
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- getOptionsOrBuilder() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.UnmountPRequest
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.UpdateMountPRequest
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- getOptionsOrBuilder() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- getOptionsOrBuilder() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- getOptionsOrBuilder() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptionsOrBuilder() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptionsOrBuilder() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- getOptionsOrDefault(String, String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
map<string, string> options = 5;
- getOptionsOrDefault(String, String) - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
map<string, string> options = 5;
- getOptionsOrDefault(String, String) - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
map<string, string> options = 5;
- getOptionsOrThrow(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
map<string, string> options = 5;
- getOptionsOrThrow(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
map<string, string> options = 5;
- getOptionsOrThrow(String) - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
map<string, string> options = 5;
- getOPType() - Method in class alluxio.proxy.s3.S3BaseTask
-
Return the OpType (S3 API enum).
- getOPType() - Method in class alluxio.worker.s3.S3NettyBaseTask
-
Return the OpType (S3 API enum).
- getOrAdd(AlluxioURI, UnderFileSystemConfiguration) - Method in class alluxio.underfs.AbstractUfsManager
-
Return a UFS instance if it already exists in the cache, otherwise, creates a new instance and
return it.
- getOrBuildCustom(String) - Static method in class alluxio.conf.PropertyKey
-
- getOrDefault(PropertyKey, T) - Method in interface alluxio.conf.AlluxioConfiguration
-
- getOrDefault(PropertyKey, Object, ConfigurationValueOptions) - Method in interface alluxio.conf.AlluxioConfiguration
-
- getOrDefault(PropertyKey, T) - Static method in class alluxio.conf.Configuration
-
- getOrDefault(PropertyKey, String, ConfigurationValueOptions) - Static method in class alluxio.conf.Configuration
-
- getOrder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
- getOrder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
-
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
- getOrder() - Method in interface alluxio.grpc.table.layout.hive.SortingColumnOrBuilder
-
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
- getOrderedStorageAliases() - Method in class alluxio.DefaultStorageTierAssoc
-
- getOrderedStorageAliases() - Method in interface alluxio.StorageTierAssoc
-
- getOrderedTierAliases() - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Gets ordered tier aliases.
- getOrdinal(String) - Method in class alluxio.DefaultStorageTierAssoc
-
- getOrdinal(String) - Method in interface alluxio.StorageTierAssoc
-
- getOrNull() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
-
- getOSSClient() - Method in class alluxio.underfs.oss.StsOssClientProvider
-
Returns the STS OSS client.
- getOtherActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- getOtherActions() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- getOtherActions() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- getOtherActions() - Method in class alluxio.security.authorization.AccessControlList
-
- getOtherActionsBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- getOtherActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- getOtherActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- getOtherActionsOrBuilder() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- getOtherBits() - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits otherBits = 3;
- getOtherBits() - Method in class alluxio.grpc.PMode
-
required .alluxio.grpc.Bits otherBits = 3;
- getOtherBits() - Method in interface alluxio.grpc.PModeOrBuilder
-
required .alluxio.grpc.Bits otherBits = 3;
- getOtherBits() - Method in class alluxio.security.authorization.Mode
-
- getOut() - Method in class alluxio.fuse.CreateFileEntry
-
Gets the opened output stream for this open file entry.
- getOut() - Method in class alluxio.fuse.OpenFileEntry
-
Gets the opened output stream for this open file entry.
- getOutput() - Method in class alluxio.shell.CommandReturn
-
Gets the stdout content.
- getOutputDirectory() - Method in class alluxio.master.backcompat.BackwardsCompatibilityJournalGenerator
-
- getOutputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string output_format = 3;
- getOutputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
optional string output_format = 3;
- getOutputFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
optional string output_format = 3;
- getOutputFormatBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string output_format = 3;
- getOutputFormatBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
optional string output_format = 3;
- getOutputFormatBytes() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
optional string output_format = 3;
- getOutputStream() - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
-
- getOutputStream() - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
-
- getOutStream(AlluxioURI, FileSystemContext, OutStreamOptions, FileOutStream, String) - Method in class alluxio.client.file.dora.DoraCacheClient
-
Get a stream to write the data to dora cache cluster.
- getOutStream(Integer) - Method in class alluxio.StreamCache
-
- getOutStream() - Method in class alluxio.worker.dora.OpenFileHandle
-
Get UFS out stream of this handle.
- getOverheadRatio() - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- getOverheadRatio() - Method in enum alluxio.client.file.cache.store.PageStoreType
-
- getOverriddenMethodDescriptors() - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
-
- getOverwrite() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool overwrite = 4;
- getOverwrite() - Method in class alluxio.grpc.CopyJobPOptions
-
optional bool overwrite = 4;
- getOverwrite() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional bool overwrite = 4;
- getOverwrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool overwrite = 13;
- getOverwrite() - Method in class alluxio.grpc.CreateFilePOptions
-
optional bool overwrite = 13;
- getOverwrite() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional bool overwrite = 13;
- getOverwrite() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool overwrite = 4;
- getOverwrite() - Method in class alluxio.grpc.MoveJobPOptions
-
optional bool overwrite = 4;
- getOverwrite() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional bool overwrite = 4;
- getOverwrite() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
optional bool overwrite = 1;
- getOverwrite() - Method in class alluxio.grpc.S3SyntaxOptions
-
optional bool overwrite = 1;
- getOverwrite() - Method in interface alluxio.grpc.S3SyntaxOptionsOrBuilder
-
optional bool overwrite = 1;
- getOverwrite() - Method in class alluxio.grpc.WriteOptions.Builder
-
optional bool overwrite = 1;
- getOverwrite() - Method in class alluxio.grpc.WriteOptions
-
optional bool overwrite = 1;
- getOverwrite() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
-
optional bool overwrite = 1;
- getOverWrite() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
-
- getOverwrite() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional bool overwrite = 10;
- getOverwrite() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional bool overwrite = 10;
- getOverwrite() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional bool overwrite = 10;
- getOverwrite() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional bool overwrite = 10;
- getOverwrite() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional bool overwrite = 10;
- getOverwrite() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional bool overwrite = 10;
- getOverwriteAccessTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool overwrite_access_time = 19;
- getOverwriteAccessTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional bool overwrite_access_time = 19;
- getOverwriteAccessTime() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional bool overwrite_access_time = 19;
- getOverwriteModificationTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool overwrite_modification_time = 8;
- getOverwriteModificationTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional bool overwrite_modification_time = 8;
- getOverwriteModificationTime() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional bool overwrite_modification_time = 8;
- getOwner() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getOwner() - Method in class alluxio.client.file.URIStatus
-
- getOwner() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string owner = 16;
- getOwner() - Method in class alluxio.grpc.FileInfo
-
optional string owner = 16;
- getOwner() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string owner = 16;
- getOwner() - Method in class alluxio.grpc.PAcl.Builder
-
optional string owner = 1;
- getOwner() - Method in class alluxio.grpc.PAcl
-
optional string owner = 1;
- getOwner() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional string owner = 1;
- getOwner() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string owner = 3;
- getOwner() - Method in class alluxio.grpc.SetAttributePOptions
-
optional string owner = 3;
- getOwner() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional string owner = 3;
- getOwner() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string owner = 4;
- getOwner() - Method in class alluxio.grpc.table.TableInfo
-
optional string owner = 4;
- getOwner() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional string owner = 4;
- getOwner() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string owner = 4;
- getOwner() - Method in class alluxio.grpc.UfsStatus
-
optional string owner = 4;
- getOwner() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string owner = 4;
- getOwner() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getOwner() - Method in class alluxio.master.file.meta.Inode
-
- getOwner() - Method in interface alluxio.master.file.meta.InodeView
-
- getOwner() - Method in class alluxio.master.file.meta.MutableInode
-
- getOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string owner = 2;
- getOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional string owner = 2;
- getOwner() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional string owner = 2;
- getOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string owner = 8;
- getOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string owner = 8;
- getOwner() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string owner = 8;
- getOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string owner = 14;
- getOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string owner = 14;
- getOwner() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string owner = 14;
- getOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string owner = 6;
- getOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string owner = 6;
- getOwner() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string owner = 6;
- getOwner() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string owner = 9;
- getOwner() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string owner = 9;
- getOwner() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string owner = 9;
- getOwner() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
-
- getOwner() - Method in class alluxio.underfs.options.CreateOptions
-
- getOwner() - Method in class alluxio.underfs.options.MkdirsOptions
-
- getOwner() - Method in class alluxio.underfs.UfsStatus
-
Gets the owner of the given path.
- getOwner(UserState) - Static method in class alluxio.util.SecurityUtils
-
- getOwner() - Method in class alluxio.util.webui.UIFileInfo
-
Gets owner.
- getOwner() - Method in class alluxio.wire.FileInfo
-
- getOwnerBits() - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits ownerBits = 1;
- getOwnerBits() - Method in class alluxio.grpc.PMode
-
required .alluxio.grpc.Bits ownerBits = 1;
- getOwnerBits() - Method in interface alluxio.grpc.PModeOrBuilder
-
required .alluxio.grpc.Bits ownerBits = 1;
- getOwnerBits() - Method in class alluxio.security.authorization.Mode
-
- getOwnerBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string owner = 16;
- getOwnerBytes() - Method in class alluxio.grpc.FileInfo
-
optional string owner = 16;
- getOwnerBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string owner = 16;
- getOwnerBytes() - Method in class alluxio.grpc.PAcl.Builder
-
optional string owner = 1;
- getOwnerBytes() - Method in class alluxio.grpc.PAcl
-
optional string owner = 1;
- getOwnerBytes() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional string owner = 1;
- getOwnerBytes() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string owner = 3;
- getOwnerBytes() - Method in class alluxio.grpc.SetAttributePOptions
-
optional string owner = 3;
- getOwnerBytes() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional string owner = 3;
- getOwnerBytes() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string owner = 4;
- getOwnerBytes() - Method in class alluxio.grpc.table.TableInfo
-
optional string owner = 4;
- getOwnerBytes() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional string owner = 4;
- getOwnerBytes() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string owner = 4;
- getOwnerBytes() - Method in class alluxio.grpc.UfsStatus
-
optional string owner = 4;
- getOwnerBytes() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string owner = 4;
- getOwnerBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string owner = 2;
- getOwnerBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional string owner = 2;
- getOwnerBytes() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional string owner = 2;
- getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string owner = 8;
- getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string owner = 8;
- getOwnerBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string owner = 8;
- getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string owner = 14;
- getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string owner = 14;
- getOwnerBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string owner = 14;
- getOwnerBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string owner = 6;
- getOwnerBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string owner = 6;
- getOwnerBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string owner = 6;
- getOwnerBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string owner = 9;
- getOwnerBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string owner = 9;
- getOwnerBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string owner = 9;
- getOwnerFromGrpcClient(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
-
- getOwnerName() - Method in class alluxio.grpc.table.Database.Builder
-
optional string owner_name = 5;
- getOwnerName() - Method in class alluxio.grpc.table.Database
-
optional string owner_name = 5;
- getOwnerName() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string owner_name = 5;
- getOwnerNameBytes() - Method in class alluxio.grpc.table.Database.Builder
-
optional string owner_name = 5;
- getOwnerNameBytes() - Method in class alluxio.grpc.table.Database
-
optional string owner_name = 5;
- getOwnerNameBytes() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string owner_name = 5;
- getOwnerType() - Method in class alluxio.grpc.table.Database.Builder
-
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
- getOwnerType() - Method in class alluxio.grpc.table.Database
-
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
- getOwnerType() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
- getOwningGroup() - Method in class alluxio.grpc.PAcl.Builder
-
optional string owningGroup = 2;
- getOwningGroup() - Method in class alluxio.grpc.PAcl
-
optional string owningGroup = 2;
- getOwningGroup() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional string owningGroup = 2;
- getOwningGroup() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningGroup = 2;
- getOwningGroup() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional string owningGroup = 2;
- getOwningGroup() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional string owningGroup = 2;
- getOwningGroup() - Method in class alluxio.security.authorization.AccessControlList
-
- getOwningGroupActions() - Method in class alluxio.security.authorization.AccessControlList
-
- getOwningGroupBytes() - Method in class alluxio.grpc.PAcl.Builder
-
optional string owningGroup = 2;
- getOwningGroupBytes() - Method in class alluxio.grpc.PAcl
-
optional string owningGroup = 2;
- getOwningGroupBytes() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional string owningGroup = 2;
- getOwningGroupBytes() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningGroup = 2;
- getOwningGroupBytes() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional string owningGroup = 2;
- getOwningGroupBytes() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional string owningGroup = 2;
- getOwningUser() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningUser = 1;
- getOwningUser() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional string owningUser = 1;
- getOwningUser() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional string owningUser = 1;
- getOwningUser() - Method in class alluxio.security.authorization.AccessControlList
-
- getOwningUserActions() - Method in class alluxio.security.authorization.AccessControlList
-
- getOwningUserBytes() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningUser = 1;
- getOwningUserBytes() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional string owningUser = 1;
- getOwningUserBytes() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional string owningUser = 1;
- getPackets() - Method in class alluxio.worker.netty.WriteRequestContext
-
- getPacketSize() - Method in class alluxio.worker.netty.ReadRequest
-
- getPacketWriteException() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
-
Get the exception object that created during packet writing.
- getPage(String, long, Channel) - Method in class alluxio.worker.http.PagedService
-
Get page bytes given fileId, pageIndex, and channel which is used for allocating ByteBuf.
- getPageFileRegion(String, long) - Method in class alluxio.worker.http.PagedService
-
Get FileRegion
object given fileId, pageIndex, and channel.
- getPageId() - Method in class alluxio.client.file.cache.PageInfo
-
- getPageIndex() - Method in class alluxio.client.file.cache.PageId
-
- getPageInfo(PageId) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
-
- getPageInfo(PageId) - Method in interface alluxio.client.file.cache.PageMetaStore
-
- getPageInfo(PageId) - Method in class alluxio.client.file.cache.QuotaPageMetaStore
-
- getPageLockId(PageId) - Method in class alluxio.client.file.cache.LocalCacheManager
-
- getPagePath(PageId, boolean) - Method in class alluxio.client.file.cache.store.LocalPageStore
-
- getPageSize() - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- getPageSize() - Method in class alluxio.client.file.cache.LocalCachePositionReader
-
Get the page size.
- getPageSize() - Method in class alluxio.client.file.cache.PageInfo
-
- getPageSize() - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- getPageSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional int64 pageSize = 1;
- getPageSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
optional int64 pageSize = 1;
- getPageSize() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
-
optional int64 pageSize = 1;
- getPageStore() - Method in class alluxio.client.file.cache.store.LocalPageStoreDir
-
Getter for pageStore.
- getPageStore() - Method in class alluxio.client.file.cache.store.MemoryPageStoreDir
-
- getPageStore() - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
- getPageStoreOptions() - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- getParallelism() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns the targeted parallelism level of this pool.
- getParameter() - Method in class alluxio.grpc.table.Database.Builder
-
Deprecated.
- getParameter() - Method in class alluxio.grpc.table.Database
-
Deprecated.
- getParameter() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
Deprecated.
- getParameterCount() - Method in class alluxio.grpc.table.Database.Builder
-
- getParameterCount() - Method in class alluxio.grpc.table.Database
-
- getParameterCount() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
map<string, string> parameter = 4;
- getParameterMap() - Method in class alluxio.grpc.table.Database.Builder
-
map<string, string> parameter = 4;
- getParameterMap() - Method in class alluxio.grpc.table.Database
-
map<string, string> parameter = 4;
- getParameterMap() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
map<string, string> parameter = 4;
- getParameterOrDefault(String, String) - Method in class alluxio.grpc.table.Database.Builder
-
map<string, string> parameter = 4;
- getParameterOrDefault(String, String) - Method in class alluxio.grpc.table.Database
-
map<string, string> parameter = 4;
- getParameterOrDefault(String, String) - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
map<string, string> parameter = 4;
- getParameterOrThrow(String) - Method in class alluxio.grpc.table.Database.Builder
-
map<string, string> parameter = 4;
- getParameterOrThrow(String) - Method in class alluxio.grpc.table.Database
-
map<string, string> parameter = 4;
- getParameterOrThrow(String) - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
map<string, string> parameter = 4;
- getParameters() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
Deprecated.
- getParameters() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
Deprecated.
- getParameters() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
Deprecated.
- getParameters() - Method in class alluxio.grpc.table.TableInfo.Builder
-
Deprecated.
- getParameters() - Method in class alluxio.grpc.table.TableInfo
-
Deprecated.
- getParameters() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
Deprecated.
- getParameters() - Method in class alluxio.stress.client.ClientIOSummary
-
- getParameters() - Method in class alluxio.stress.client.ClientIOTaskResult
-
- getParameters() - Method in class alluxio.stress.worker.IOTaskResult
-
- getParameters() - Method in class alluxio.stress.worker.IOTaskSummary
-
- getParameters() - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- getParameters() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- getParameters() - Method in class alluxio.worker.http.HttpRequestUri
-
Get the parameters map.
- getParametersCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- getParametersCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
- getParametersCount() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
map<string, string> parameters = 7;
- getParametersCount() - Method in class alluxio.grpc.table.TableInfo.Builder
-
- getParametersCount() - Method in class alluxio.grpc.table.TableInfo
-
- getParametersCount() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
map<string, string> parameters = 7;
- getParametersMap() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
map<string, string> parameters = 7;
- getParametersMap() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
map<string, string> parameters = 7;
- getParametersMap() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
map<string, string> parameters = 7;
- getParametersMap() - Method in class alluxio.grpc.table.TableInfo.Builder
-
map<string, string> parameters = 7;
- getParametersMap() - Method in class alluxio.grpc.table.TableInfo
-
map<string, string> parameters = 7;
- getParametersMap() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
map<string, string> parameters = 7;
- getParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
map<string, string> parameters = 7;
- getParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
map<string, string> parameters = 7;
- getParametersOrDefault(String, String) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
map<string, string> parameters = 7;
- getParametersOrDefault(String, String) - Method in class alluxio.grpc.table.TableInfo.Builder
-
map<string, string> parameters = 7;
- getParametersOrDefault(String, String) - Method in class alluxio.grpc.table.TableInfo
-
map<string, string> parameters = 7;
- getParametersOrDefault(String, String) - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
map<string, string> parameters = 7;
- getParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
map<string, string> parameters = 7;
- getParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
map<string, string> parameters = 7;
- getParametersOrThrow(String) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
map<string, string> parameters = 7;
- getParametersOrThrow(String) - Method in class alluxio.grpc.table.TableInfo.Builder
-
map<string, string> parameters = 7;
- getParametersOrThrow(String) - Method in class alluxio.grpc.table.TableInfo
-
map<string, string> parameters = 7;
- getParametersOrThrow(String) - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
map<string, string> parameters = 7;
- getParent() - Method in class alluxio.AlluxioURI
-
Get the parent of this
AlluxioURI
or null if at root.
- getParent(String) - Static method in class alluxio.util.io.PathUtils
-
Gets the parent of the file at a path.
- getParentCleaned(String) - Static method in class alluxio.util.io.PathUtils
-
- getParentCommandName() - Method in class alluxio.cli.command.AbstractFuseShellCommand
-
Gets the parent command name.
- getParentDir() - Method in interface alluxio.worker.block.meta.BlockMeta
-
- getParentDir() - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- getParentId() - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 parentId = 10;
- getParentId() - Method in class alluxio.grpc.JobInfo
-
optional int64 parentId = 10;
- getParentId() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional int64 parentId = 10;
- getParentId() - Method in interface alluxio.job.wire.JobInfo
-
- getParentId() - Method in class alluxio.job.wire.PlanInfo
-
- getParentId() - Method in class alluxio.job.wire.TaskInfo
-
- getParentId() - Method in class alluxio.job.wire.WorkflowInfo
-
- getParentId() - Method in class alluxio.master.file.meta.EdgeEntry
-
- getParentId() - Method in class alluxio.master.file.meta.Inode
-
- getParentId() - Method in interface alluxio.master.file.meta.InodeView
-
- getParentId() - Method in class alluxio.master.file.meta.MutableInode
-
- getParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 parent_id = 2;
- getParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 parent_id = 2;
- getParentId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 parent_id = 2;
- getParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 parent_id = 2;
- getParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 parent_id = 2;
- getParentId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 parent_id = 2;
- getParentId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 parent_id = 2;
- getParentId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 parent_id = 2;
- getParentId() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 parent_id = 2;
- getParentId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 parent_id = 7;
- getParentId() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 parent_id = 7;
- getParentId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 parent_id = 7;
- getParentInodeDirectory() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getParentInodeOrNull() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getParentPath(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Get parent path.
- getParents(T) - Method in class alluxio.collections.DirectedAcyclicGraph
-
Gets the payloads for the given nodes parents.
- getParents() - Method in class alluxio.collections.DirectedAcyclicGraphNode
-
Gets the parent nodes of the node.
- getParentSubject() - Method in class alluxio.grpc.GrpcChannelBuilder
-
- getParentTier() - Method in interface alluxio.worker.block.meta.StorageDir
-
- getParsedFingerprint(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getParsedFingerprint(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getParsedFingerprint(String) - Method in class alluxio.underfs.BaseUnderFileSystem
-
- getParsedFingerprint(String, String) - Method in class alluxio.underfs.BaseUnderFileSystem
-
- getParsedFingerprint(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Computes and returns a fingerprint for the path.
- getParsedFingerprint(String, String) - Method in interface alluxio.underfs.UnderFileSystem
-
- getParsedFingerprint(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getParsedFingerprint(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getParserForType() - Method in class alluxio.grpc.ActionInfo
-
- getParserForType() - Method in class alluxio.grpc.AddPolicyPOptions
-
- getParserForType() - Method in class alluxio.grpc.AddPolicyPRequest
-
- getParserForType() - Method in class alluxio.grpc.AddPolicyPResponse
-
- getParserForType() - Method in class alluxio.grpc.AddQuorumServerRequest
-
- getParserForType() - Method in class alluxio.grpc.AsyncCacheRequest
-
- getParserForType() - Method in class alluxio.grpc.AsyncCacheResponse
-
- getParserForType() - Method in class alluxio.grpc.BackupPOptions
-
- getParserForType() - Method in class alluxio.grpc.BackupPRequest
-
- getParserForType() - Method in class alluxio.grpc.BackupPStatus
-
- getParserForType() - Method in class alluxio.grpc.BackupStatusPRequest
-
- getParserForType() - Method in class alluxio.grpc.Block
-
- getParserForType() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
- getParserForType() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
- getParserForType() - Method in class alluxio.grpc.BlockHeartbeatPResponse
-
- getParserForType() - Method in class alluxio.grpc.BlockIdList
-
- getParserForType() - Method in class alluxio.grpc.BlockInfo
-
- getParserForType() - Method in class alluxio.grpc.BlockLocation
-
- getParserForType() - Method in class alluxio.grpc.BlockMasterInfo
-
- getParserForType() - Method in class alluxio.grpc.BlockStatus
-
- getParserForType() - Method in class alluxio.grpc.BlockStoreLocationProto
-
- getParserForType() - Method in class alluxio.grpc.BuildVersion
-
- getParserForType() - Method in class alluxio.grpc.CacheRequest
-
- getParserForType() - Method in class alluxio.grpc.CacheResponse
-
- getParserForType() - Method in class alluxio.grpc.CancelPOptions
-
- getParserForType() - Method in class alluxio.grpc.CancelPRequest
-
- getParserForType() - Method in class alluxio.grpc.CancelPResponse
-
- getParserForType() - Method in class alluxio.grpc.CancelTaskCommand
-
- getParserForType() - Method in class alluxio.grpc.CheckAccessPOptions
-
- getParserForType() - Method in class alluxio.grpc.CheckAccessPRequest
-
- getParserForType() - Method in class alluxio.grpc.CheckAccessPResponse
-
- getParserForType() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
- getParserForType() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
- getParserForType() - Method in class alluxio.grpc.CheckConsistencyPResponse
-
- getParserForType() - Method in class alluxio.grpc.CheckpointPOptions
-
- getParserForType() - Method in class alluxio.grpc.CheckpointPResponse
-
- getParserForType() - Method in class alluxio.grpc.CheckRequest
-
- getParserForType() - Method in class alluxio.grpc.CheckResponse
-
- getParserForType() - Method in class alluxio.grpc.Chunk
-
- getParserForType() - Method in class alluxio.grpc.ClearMetricsPRequest
-
- getParserForType() - Method in class alluxio.grpc.ClearMetricsPResponse
-
- getParserForType() - Method in class alluxio.grpc.ClearMetricsRequest
-
- getParserForType() - Method in class alluxio.grpc.ClearMetricsResponse
-
- getParserForType() - Method in class alluxio.grpc.ClientMetrics
-
- getParserForType() - Method in class alluxio.grpc.CmdProgress
-
- getParserForType() - Method in class alluxio.grpc.CmdStatusBlock
-
- getParserForType() - Method in class alluxio.grpc.CmdSummary
-
- getParserForType() - Method in class alluxio.grpc.Command
-
- getParserForType() - Method in class alluxio.grpc.CommitBlockPOptions
-
- getParserForType() - Method in class alluxio.grpc.CommitBlockPRequest
-
- getParserForType() - Method in class alluxio.grpc.CommitBlockPResponse
-
- getParserForType() - Method in class alluxio.grpc.CompleteFilePOptions
-
- getParserForType() - Method in class alluxio.grpc.CompleteFilePRequest
-
- getParserForType() - Method in class alluxio.grpc.CompleteFilePResponse
-
- getParserForType() - Method in class alluxio.grpc.ConfigCheckReport
-
- getParserForType() - Method in class alluxio.grpc.ConfigProperties
-
- getParserForType() - Method in class alluxio.grpc.ConfigProperty
-
- getParserForType() - Method in class alluxio.grpc.CopyJobPOptions
-
- getParserForType() - Method in class alluxio.grpc.CopyRequest
-
- getParserForType() - Method in class alluxio.grpc.CopyResponse
-
- getParserForType() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
- getParserForType() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
- getParserForType() - Method in class alluxio.grpc.CreateDirectoryPResponse
-
- getParserForType() - Method in class alluxio.grpc.CreateFilePOptions
-
- getParserForType() - Method in class alluxio.grpc.CreateFilePRequest
-
- getParserForType() - Method in class alluxio.grpc.CreateFilePResponse
-
- getParserForType() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
- getParserForType() - Method in class alluxio.grpc.DecommissionWorkerPResponse
-
- getParserForType() - Method in class alluxio.grpc.DeletePOptions
-
- getParserForType() - Method in class alluxio.grpc.DeletePRequest
-
- getParserForType() - Method in class alluxio.grpc.DeletePResponse
-
- getParserForType() - Method in class alluxio.grpc.DownloadSnapshotPRequest
-
Deprecated.
- getParserForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
Deprecated.
- getParserForType() - Method in class alluxio.grpc.ErrorInfo
-
- getParserForType() - Method in class alluxio.grpc.ExistsPOptions
-
- getParserForType() - Method in class alluxio.grpc.ExistsPRequest
-
- getParserForType() - Method in class alluxio.grpc.ExistsPResponse
-
- getParserForType() - Method in class alluxio.grpc.File
-
- getParserForType() - Method in class alluxio.grpc.FileBlockInfo
-
- getParserForType() - Method in class alluxio.grpc.FileFailure
-
- getParserForType() - Method in class alluxio.grpc.FileInfo
-
- getParserForType() - Method in class alluxio.grpc.FileSystemCommand
-
- getParserForType() - Method in class alluxio.grpc.FileSystemCommandOptions
-
- getParserForType() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
- getParserForType() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
- getParserForType() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
-
- getParserForType() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
- getParserForType() - Method in class alluxio.grpc.FreePOptions
-
- getParserForType() - Method in class alluxio.grpc.FreePRequest
-
- getParserForType() - Method in class alluxio.grpc.FreePResponse
-
- getParserForType() - Method in class alluxio.grpc.FreeWorkerRequest
-
- getParserForType() - Method in class alluxio.grpc.FreeWorkerResponse
-
- getParserForType() - Method in class alluxio.grpc.FsOpPId
-
- getParserForType() - Method in class alluxio.grpc.GetActionInfoOptions
-
- getParserForType() - Method in class alluxio.grpc.GetActionInfoRequest
-
- getParserForType() - Method in class alluxio.grpc.GetActionInfoResponse
-
- getParserForType() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetBlockInfoPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetBlockInfoPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetBlockInfoPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetCapacityBytesPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetCapacityBytesPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
-
- getParserForType() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
- getParserForType() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
-
- getParserForType() - Method in class alluxio.grpc.GetCmdStatusOptions
-
- getParserForType() - Method in class alluxio.grpc.GetCmdStatusRequest
-
- getParserForType() - Method in class alluxio.grpc.GetCmdStatusResponse
-
- getParserForType() - Method in class alluxio.grpc.GetConfigHashPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetConfigHashPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetConfigReportPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetConfigReportPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetConfigurationPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetConfigurationPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetFileInfoPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetFileInfoPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetFileInfoPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetFilePathPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetFilePathPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetJobMasterIdPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetJobMasterIdPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetJobProgressPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetJobProgressPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetJobStatusPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetJobStatusPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetJobStatusPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetMasterIdPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetMasterIdPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetMasterIdPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetMasterInfoPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetMasterInfoPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetMetricsPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetMetricsPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetMountIdPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetMountIdPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetMountTablePRequest
-
- getParserForType() - Method in class alluxio.grpc.GetMountTablePResponse
-
- getParserForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
- getParserForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
- getParserForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
-
- getParserForType() - Method in class alluxio.grpc.GetNodeStatePRequest
-
- getParserForType() - Method in class alluxio.grpc.GetNodeStatePResponse
-
- getParserForType() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetPolicyStatusPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetPolicyStatusPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetQuorumInfoPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetQuorumInfoPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetRegisterLeasePOptions
-
- getParserForType() - Method in class alluxio.grpc.GetRegisterLeasePRequest
-
- getParserForType() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
- getParserForType() - Method in class alluxio.grpc.GetServiceVersionPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetServiceVersionPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- getParserForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse
-
Deprecated.
- getParserForType() - Method in class alluxio.grpc.GetSnapshotRequest
-
Deprecated.
- getParserForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetStatusPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetStatusPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetStatusPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
-
- getParserForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
-
- getParserForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
-
- getParserForType() - Method in class alluxio.grpc.GetUfsInfoPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetUfsInfoPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetUfsInfoPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetUsedBytesPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetUsedBytesPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetWorkerIdPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
- getParserForType() - Method in class alluxio.grpc.GetWorkerIdPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
-
- getParserForType() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
-
- getParserForType() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
-
- getParserForType() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
- getParserForType() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
- getParserForType() - Method in class alluxio.grpc.InconsistentProperties
-
- getParserForType() - Method in class alluxio.grpc.InconsistentProperty
-
- getParserForType() - Method in class alluxio.grpc.InconsistentPropertyValues
-
- getParserForType() - Method in class alluxio.grpc.JobCommand
-
- getParserForType() - Method in class alluxio.grpc.JobDescription
-
- getParserForType() - Method in class alluxio.grpc.JobHeartbeatPOptions
-
- getParserForType() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
- getParserForType() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
- getParserForType() - Method in class alluxio.grpc.JobInfo
-
- getParserForType() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
-
- getParserForType() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
- getParserForType() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
-
- getParserForType() - Method in class alluxio.grpc.JobMasterStatus
-
- getParserForType() - Method in class alluxio.grpc.JobProgress
-
- getParserForType() - Method in class alluxio.grpc.JobProgressPOptions
-
- getParserForType() - Method in class alluxio.grpc.JobServiceSummary
-
- getParserForType() - Method in class alluxio.grpc.JobStatusBlock
-
- getParserForType() - Method in class alluxio.grpc.JobUnused
-
- getParserForType() - Method in class alluxio.grpc.JobWorkerHealth
-
- getParserForType() - Method in class alluxio.grpc.JournalQueryRequest
-
- getParserForType() - Method in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- getParserForType() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
-
- getParserForType() - Method in class alluxio.grpc.ListAllPOptions
-
- getParserForType() - Method in class alluxio.grpc.ListAllPRequest
-
- getParserForType() - Method in class alluxio.grpc.ListAllPResponse
-
- getParserForType() - Method in class alluxio.grpc.ListPolicyPOptions
-
- getParserForType() - Method in class alluxio.grpc.ListPolicyPRequest
-
- getParserForType() - Method in class alluxio.grpc.ListPolicyPResponse
-
- getParserForType() - Method in class alluxio.grpc.ListProxyStatusPOptions
-
- getParserForType() - Method in class alluxio.grpc.ListProxyStatusPRequest
-
- getParserForType() - Method in class alluxio.grpc.ListProxyStatusPResponse
-
- getParserForType() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
- getParserForType() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
- getParserForType() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
- getParserForType() - Method in class alluxio.grpc.ListStatusPOptions
-
- getParserForType() - Method in class alluxio.grpc.ListStatusPRequest
-
- getParserForType() - Method in class alluxio.grpc.ListStatusPResponse
-
- getParserForType() - Method in class alluxio.grpc.LoadFileFailure
-
- getParserForType() - Method in class alluxio.grpc.LoadFileRequest
-
- getParserForType() - Method in class alluxio.grpc.LoadFileResponse
-
- getParserForType() - Method in class alluxio.grpc.LoadJobPOptions
-
- getParserForType() - Method in class alluxio.grpc.LoadMetadataPOptions
-
- getParserForType() - Method in class alluxio.grpc.LoadRequest
-
- getParserForType() - Method in class alluxio.grpc.LoadResponse
-
- getParserForType() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
- getParserForType() - Method in class alluxio.grpc.MasterHeartbeatPOptions
-
- getParserForType() - Method in class alluxio.grpc.MasterHeartbeatPRequest
-
- getParserForType() - Method in class alluxio.grpc.MasterHeartbeatPResponse
-
- getParserForType() - Method in class alluxio.grpc.MasterInfo
-
- getParserForType() - Method in class alluxio.grpc.MasterVersion
-
- getParserForType() - Method in class alluxio.grpc.MessagingRequestHeader
-
- getParserForType() - Method in class alluxio.grpc.MessagingResponseHeader
-
- getParserForType() - Method in class alluxio.grpc.Metric
-
- getParserForType() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
-
- getParserForType() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
-
- getParserForType() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
-
- getParserForType() - Method in class alluxio.grpc.MetricValue
-
- getParserForType() - Method in class alluxio.grpc.MountPointInfo
-
- getParserForType() - Method in class alluxio.grpc.MountPOptions
-
- getParserForType() - Method in class alluxio.grpc.MountPRequest
-
- getParserForType() - Method in class alluxio.grpc.MountPResponse
-
- getParserForType() - Method in class alluxio.grpc.MoveBlockRequest
-
- getParserForType() - Method in class alluxio.grpc.MoveBlockResponse
-
- getParserForType() - Method in class alluxio.grpc.MoveJobPOptions
-
- getParserForType() - Method in class alluxio.grpc.MoveRequest
-
- getParserForType() - Method in class alluxio.grpc.MoveResponse
-
- getParserForType() - Method in class alluxio.grpc.NeedsSyncRequest
-
- getParserForType() - Method in class alluxio.grpc.NeedsSyncResponse
-
- getParserForType() - Method in class alluxio.grpc.NetAddress
-
- getParserForType() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
-
- getParserForType() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
- getParserForType() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
-
- getParserForType() - Method in class alluxio.grpc.OpenFilePOptions
-
- getParserForType() - Method in class alluxio.grpc.PAcl
-
- getParserForType() - Method in class alluxio.grpc.PAclEntry
-
- getParserForType() - Method in class alluxio.grpc.PersistCommandOptions
-
- getParserForType() - Method in class alluxio.grpc.PersistFile
-
- getParserForType() - Method in class alluxio.grpc.PMode
-
- getParserForType() - Method in class alluxio.grpc.PolicyInfo
-
- getParserForType() - Method in class alluxio.grpc.PolicyStatus
-
- getParserForType() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
- getParserForType() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
-
- getParserForType() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
-
- getParserForType() - Method in class alluxio.grpc.ProxyStatus
-
- getParserForType() - Method in class alluxio.grpc.QuorumServerInfo
-
- getParserForType() - Method in class alluxio.grpc.ReadRequest
-
- getParserForType() - Method in class alluxio.grpc.ReadResponse
-
- getParserForType() - Method in class alluxio.grpc.RegisterCommand
-
- getParserForType() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
- getParserForType() - Method in class alluxio.grpc.RegisterJobMasterPRequest
-
- getParserForType() - Method in class alluxio.grpc.RegisterJobMasterPResponse
-
- getParserForType() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
-
- getParserForType() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
- getParserForType() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
-
- getParserForType() - Method in class alluxio.grpc.RegisterMasterPOptions
-
- getParserForType() - Method in class alluxio.grpc.RegisterMasterPRequest
-
- getParserForType() - Method in class alluxio.grpc.RegisterMasterPResponse
-
- getParserForType() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
- getParserForType() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
- getParserForType() - Method in class alluxio.grpc.RegisterWorkerPResponse
-
- getParserForType() - Method in class alluxio.grpc.RemoveBlockRequest
-
- getParserForType() - Method in class alluxio.grpc.RemoveBlockResponse
-
- getParserForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
- getParserForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
-
- getParserForType() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
-
- getParserForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
- getParserForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
-
- getParserForType() - Method in class alluxio.grpc.RemovePolicyPOptions
-
- getParserForType() - Method in class alluxio.grpc.RemovePolicyPRequest
-
- getParserForType() - Method in class alluxio.grpc.RemovePolicyPResponse
-
- getParserForType() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
-
- getParserForType() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
- getParserForType() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
-
- getParserForType() - Method in class alluxio.grpc.RenamePOptions
-
- getParserForType() - Method in class alluxio.grpc.RenamePRequest
-
- getParserForType() - Method in class alluxio.grpc.RenamePResponse
-
- getParserForType() - Method in class alluxio.grpc.ResetPrioritiesPOptions
-
- getParserForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest
-
- getParserForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse
-
- getParserForType() - Method in class alluxio.grpc.RetryInfo
-
- getParserForType() - Method in class alluxio.grpc.ReverseResolvePRequest
-
- getParserForType() - Method in class alluxio.grpc.ReverseResolvePResponse
-
- getParserForType() - Method in class alluxio.grpc.Route
-
- getParserForType() - Method in class alluxio.grpc.RouteFailure
-
- getParserForType() - Method in class alluxio.grpc.RunPOptions
-
- getParserForType() - Method in class alluxio.grpc.RunPRequest
-
- getParserForType() - Method in class alluxio.grpc.RunPResponse
-
- getParserForType() - Method in class alluxio.grpc.RunTaskCommand
-
- getParserForType() - Method in class alluxio.grpc.S3SyntaxOptions
-
- getParserForType() - Method in class alluxio.grpc.SaslMessage
-
- getParserForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
- getParserForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
- getParserForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
-
- getParserForType() - Method in class alluxio.grpc.SetAclPOptions
-
- getParserForType() - Method in class alluxio.grpc.SetAclPRequest
-
- getParserForType() - Method in class alluxio.grpc.SetAclPResponse
-
- getParserForType() - Method in class alluxio.grpc.SetAttributePOptions
-
- getParserForType() - Method in class alluxio.grpc.SetAttributePRequest
-
- getParserForType() - Method in class alluxio.grpc.SetAttributePResponse
-
- getParserForType() - Method in class alluxio.grpc.SetPathConfigurationPOptions
-
- getParserForType() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
- getParserForType() - Method in class alluxio.grpc.SetPathConfigurationPResponse
-
- getParserForType() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
-
- getParserForType() - Method in class alluxio.grpc.SnapshotData
-
- getParserForType() - Method in class alluxio.grpc.SnapshotMetadata
-
- getParserForType() - Method in class alluxio.grpc.StatusSummary
-
- getParserForType() - Method in class alluxio.grpc.StopJobPRequest
-
- getParserForType() - Method in class alluxio.grpc.StopJobPResponse
-
- getParserForType() - Method in class alluxio.grpc.StorageList
-
- getParserForType() - Method in class alluxio.grpc.SubmitJobPRequest
-
- getParserForType() - Method in class alluxio.grpc.SubmitJobPResponse
-
- getParserForType() - Method in class alluxio.grpc.SubmitOptions
-
- getParserForType() - Method in class alluxio.grpc.SubmitRequest
-
- getParserForType() - Method in class alluxio.grpc.SubmitResponse
-
- getParserForType() - Method in class alluxio.grpc.table.AllOrNoneSet
-
- getParserForType() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
- getParserForType() - Method in class alluxio.grpc.table.AttachDatabasePResponse
-
- getParserForType() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
- getParserForType() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
- getParserForType() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
- getParserForType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
- getParserForType() - Method in class alluxio.grpc.table.ColumnStatisticsList
-
- getParserForType() - Method in class alluxio.grpc.table.Constraint
-
- getParserForType() - Method in class alluxio.grpc.table.Database
-
- getParserForType() - Method in class alluxio.grpc.table.Date
-
- getParserForType() - Method in class alluxio.grpc.table.DateColumnStatsData
-
- getParserForType() - Method in class alluxio.grpc.table.Decimal
-
- getParserForType() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
- getParserForType() - Method in class alluxio.grpc.table.DetachDatabasePRequest
-
- getParserForType() - Method in class alluxio.grpc.table.DetachDatabasePResponse
-
- getParserForType() - Method in class alluxio.grpc.table.Domain
-
- getParserForType() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
- getParserForType() - Method in class alluxio.grpc.table.EquatableValueSet
-
- getParserForType() - Method in class alluxio.grpc.table.FieldSchema
-
- getParserForType() - Method in class alluxio.grpc.table.FileStatistics
-
- getParserForType() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
-
- getParserForType() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
- getParserForType() - Method in class alluxio.grpc.table.GetAllTablesPRequest
-
- getParserForType() - Method in class alluxio.grpc.table.GetAllTablesPResponse
-
- getParserForType() - Method in class alluxio.grpc.table.GetDatabasePRequest
-
- getParserForType() - Method in class alluxio.grpc.table.GetDatabasePResponse
-
- getParserForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
- getParserForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
- getParserForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
- getParserForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
- getParserForType() - Method in class alluxio.grpc.table.GetTablePRequest
-
- getParserForType() - Method in class alluxio.grpc.table.GetTablePResponse
-
- getParserForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
-
- getParserForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
- getParserForType() - Method in class alluxio.grpc.table.Layout
-
- getParserForType() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
- getParserForType() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
- getParserForType() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
-
- getParserForType() - Method in class alluxio.grpc.table.layout.hive.Storage
-
- getParserForType() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
- getParserForType() - Method in class alluxio.grpc.table.LayoutSpec
-
- getParserForType() - Method in class alluxio.grpc.table.LongColumnStatsData
-
- getParserForType() - Method in class alluxio.grpc.table.Partition
-
- getParserForType() - Method in class alluxio.grpc.table.PartitionSpec
-
- getParserForType() - Method in class alluxio.grpc.table.Range
-
- getParserForType() - Method in class alluxio.grpc.table.RangeSet
-
- getParserForType() - Method in class alluxio.grpc.table.ReadTablePRequest
-
- getParserForType() - Method in class alluxio.grpc.table.ReadTablePResponse
-
- getParserForType() - Method in class alluxio.grpc.table.Schema
-
- getParserForType() - Method in class alluxio.grpc.table.StringColumnStatsData
-
- getParserForType() - Method in class alluxio.grpc.table.SyncDatabasePRequest
-
- getParserForType() - Method in class alluxio.grpc.table.SyncDatabasePResponse
-
- getParserForType() - Method in class alluxio.grpc.table.SyncStatus
-
- getParserForType() - Method in class alluxio.grpc.table.TableInfo
-
- getParserForType() - Method in class alluxio.grpc.table.Transformation
-
- getParserForType() - Method in class alluxio.grpc.table.TransformJobInfo
-
- getParserForType() - Method in class alluxio.grpc.table.TransformTablePRequest
-
- getParserForType() - Method in class alluxio.grpc.table.TransformTablePResponse
-
- getParserForType() - Method in class alluxio.grpc.table.Value
-
- getParserForType() - Method in class alluxio.grpc.TierList
-
- getParserForType() - Method in class alluxio.grpc.TransferLeaderMessage
-
- getParserForType() - Method in class alluxio.grpc.TransferLeadershipPOptions
-
- getParserForType() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
- getParserForType() - Method in class alluxio.grpc.TransferLeadershipPResponse
-
- getParserForType() - Method in class alluxio.grpc.TransportMessage
-
- getParserForType() - Method in class alluxio.grpc.TriggerPolicyRequest
-
- getParserForType() - Method in class alluxio.grpc.TriggerPolicyResponse
-
- getParserForType() - Method in class alluxio.grpc.UfsFileStatus
-
- getParserForType() - Method in class alluxio.grpc.UfsInfo
-
- getParserForType() - Method in class alluxio.grpc.UfsReadOptions
-
- getParserForType() - Method in class alluxio.grpc.UfsStatus
-
- getParserForType() - Method in class alluxio.grpc.UnmountPOptions
-
- getParserForType() - Method in class alluxio.grpc.UnmountPRequest
-
- getParserForType() - Method in class alluxio.grpc.UnmountPResponse
-
- getParserForType() - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
- getParserForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
- getParserForType() - Method in class alluxio.grpc.UpdateMountPRequest
-
- getParserForType() - Method in class alluxio.grpc.UpdateMountPResponse
-
- getParserForType() - Method in class alluxio.grpc.UpdateUfsModePOptions
-
- getParserForType() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
- getParserForType() - Method in class alluxio.grpc.UpdateUfsModePResponse
-
- getParserForType() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
Deprecated.
- getParserForType() - Method in class alluxio.grpc.UploadSnapshotPResponse
-
Deprecated.
- getParserForType() - Method in class alluxio.grpc.WorkerIdentity
-
- getParserForType() - Method in class alluxio.grpc.WorkerInfo
-
- getParserForType() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
- getParserForType() - Method in class alluxio.grpc.WorkerNetAddress
-
- getParserForType() - Method in class alluxio.grpc.WriteOptions
-
- getParserForType() - Method in class alluxio.grpc.WriteRequest
-
- getParserForType() - Method in class alluxio.grpc.WriteRequestCommand
-
- getParserForType() - Method in class alluxio.grpc.WriteResponse
-
- getParserForType() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
- getParserForType() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.Response
-
- getParserForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
- getParserForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.NewBlockEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.RenameEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.SetAclEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.StringPairEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- getParserForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Job.FileFilter
-
- getParserForType() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Journal.JournalOpPId
-
- getParserForType() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
- getParserForType() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
-
- getParserForType() - Method in class alluxio.proto.meta.Block.BlockLocation
-
- getParserForType() - Method in class alluxio.proto.meta.Block.BlockMeta
-
- getParserForType() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
-
- getParserForType() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
- getParserForType() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
- getParserForType() - Method in class alluxio.proto.shared.Acl.AclActions
-
- getParserForType() - Method in class alluxio.proto.shared.Acl.AclEntry
-
- getParserForType() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
- getPartialListing() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool partialListing = 3;
- getPartialListing() - Method in class alluxio.grpc.CopyJobPOptions
-
optional bool partialListing = 3;
- getPartialListing() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional bool partialListing = 3;
- getPartialListing() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool partialListing = 3;
- getPartialListing() - Method in class alluxio.grpc.LoadJobPOptions
-
optional bool partialListing = 3;
- getPartialListing() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
-
optional bool partialListing = 3;
- getPartialListing() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool partialListing = 3;
- getPartialListing() - Method in class alluxio.grpc.MoveJobPOptions
-
optional bool partialListing = 3;
- getPartialListing() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional bool partialListing = 3;
- getPartialListing() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required bool partialListing = 7;
- getPartialListing() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required bool partialListing = 7;
- getPartialListing() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required bool partialListing = 7;
- getPartialListing() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required bool partialListing = 6;
- getPartialListing() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required bool partialListing = 6;
- getPartialListing() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required bool partialListing = 6;
- getPartialListing() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required bool partialListing = 7;
- getPartialListing() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required bool partialListing = 7;
- getPartialListing() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required bool partialListing = 7;
- getPartialOptions() - Method in class alluxio.master.file.contexts.ListStatusContext
-
- getPartition() - Method in class alluxio.client.hive.HiveCacheContext
-
- getPartitionCols(int) - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- getPartitionCols(int) - Method in class alluxio.grpc.table.TableInfo
-
partitioning scheme
- getPartitionCols(int) - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
partitioning scheme
- getPartitionColsBuilder(int) - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- getPartitionColsBuilderList() - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- getPartitionColsCount() - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- getPartitionColsCount() - Method in class alluxio.grpc.table.TableInfo
-
partitioning scheme
- getPartitionColsCount() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
partitioning scheme
- getPartitionColsList() - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- getPartitionColsList() - Method in class alluxio.grpc.table.TableInfo
-
partitioning scheme
- getPartitionColsList() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
partitioning scheme
- getPartitionColsOrBuilder(int) - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- getPartitionColsOrBuilder(int) - Method in class alluxio.grpc.table.TableInfo
-
partitioning scheme
- getPartitionColsOrBuilder(int) - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
partitioning scheme
- getPartitionColsOrBuilderList() - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- getPartitionColsOrBuilderList() - Method in class alluxio.grpc.table.TableInfo
-
partitioning scheme
- getPartitionColsOrBuilderList() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
partitioning scheme
- getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in interface alluxio.client.table.TableMasterClient
-
Get column statistics for selected partition and column.
- getPartitionColumnStatistics(GetPartitionColumnStatisticsPRequest, StreamObserver<GetPartitionColumnStatisticsPResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
-
- getPartitionColumnStatistics(GetPartitionColumnStatisticsPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
-
- getPartitionColumnStatistics(GetPartitionColumnStatisticsPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
-
- getPartitionColumnStatistics(GetPartitionColumnStatisticsPRequest, StreamObserver<GetPartitionColumnStatisticsPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
-
- GetPartitionColumnStatisticsPRequest - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
- GetPartitionColumnStatisticsPRequest.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
- GetPartitionColumnStatisticsPRequestOrBuilder - Interface in alluxio.grpc.table
-
- GetPartitionColumnStatisticsPResponse - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
- GetPartitionColumnStatisticsPResponse.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
- GetPartitionColumnStatisticsPResponseOrBuilder - Interface in alluxio.grpc.table
-
- getPartitionName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
partition name in the form of "key=value"
- getPartitionName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
partition name in the form of "key=value"
- getPartitionName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
partition name in the form of "key=value"
- getPartitionNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
partition name in the form of "key=value"
- getPartitionNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
partition name in the form of "key=value"
- getPartitionNameBytes() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
partition name in the form of "key=value"
- getPartitionNames(String, String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getPartitionNames(String, String) - Method in interface alluxio.client.table.TableMasterClient
-
Get partition names with given database name and table name.
- getPartitions(int) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitions(int) - Method in class alluxio.grpc.table.ReadTablePResponse
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitions(int) - Method in interface alluxio.grpc.table.ReadTablePResponseOrBuilder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsBuilder(int) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsBuilderList() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsCount() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsCount() - Method in class alluxio.grpc.table.ReadTablePResponse
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsCount() - Method in interface alluxio.grpc.table.ReadTablePResponseOrBuilder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsList() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsList() - Method in class alluxio.grpc.table.ReadTablePResponse
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsList() - Method in interface alluxio.grpc.table.ReadTablePResponseOrBuilder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsOrBuilder(int) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsOrBuilder(int) - Method in class alluxio.grpc.table.ReadTablePResponse
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsOrBuilder(int) - Method in interface alluxio.grpc.table.ReadTablePResponseOrBuilder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsOrBuilderList() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsOrBuilderList() - Method in class alluxio.grpc.table.ReadTablePResponse
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionsOrBuilderList() - Method in interface alluxio.grpc.table.ReadTablePResponseOrBuilder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- getPartitionSpec() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- getPartitionSpec() - Method in class alluxio.grpc.table.Partition
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- getPartitionSpec() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- getPartitionSpecBuilder() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- getPartitionSpecOrBuilder() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- getPartitionSpecOrBuilder() - Method in class alluxio.grpc.table.Partition
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- getPartitionSpecOrBuilder() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- getPartitionStatistics() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
Deprecated.
- getPartitionStatistics() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
Deprecated.
- getPartitionStatistics() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
-
Deprecated.
- getPartitionStatisticsCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- getPartitionStatisticsCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
- getPartitionStatisticsCount() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- getPartitionStatisticsMap() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- getPartitionStatisticsMap() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- getPartitionStatisticsMap() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- getPartitionStatisticsOrDefault(String, ColumnStatisticsList) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- getPartitionStatisticsOrDefault(String, ColumnStatisticsList) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- getPartitionStatisticsOrDefault(String, ColumnStatisticsList) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- getPartitionStatisticsOrThrow(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- getPartitionStatisticsOrThrow(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- getPartitionStatisticsOrThrow(String) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
- getPartNames(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string part_names = 4;
- getPartNames(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
repeated string part_names = 4;
- getPartNames(int) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
repeated string part_names = 4;
- getPartNamesBytes(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string part_names = 4;
- getPartNamesBytes(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
repeated string part_names = 4;
- getPartNamesBytes(int) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
repeated string part_names = 4;
- getPartNamesCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string part_names = 4;
- getPartNamesCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
repeated string part_names = 4;
- getPartNamesCount() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
repeated string part_names = 4;
- getPartNamesList() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string part_names = 4;
- getPartNamesList() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
repeated string part_names = 4;
- getPartNamesList() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
repeated string part_names = 4;
- getPartNumber() - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest.Part
-
- getPartNumber() - Method in class alluxio.proxy.s3.ListPartsResult.Part
-
- getPartNumber() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
-
Get the part number.
- getParts() - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest
-
- getParts() - Method in class alluxio.proxy.s3.ListPartsResult
-
- getPath() - Method in class alluxio.AlluxioURI
-
- getPath() - Method in class alluxio.client.file.URIStatus
-
For example, for the uri: alluxio://host:1000/foo/bar/baz, the path is /foo/bar/baz.
- getPath() - Method in class alluxio.fuse.CreateFileEntry
-
- getPath() - Method in class alluxio.fuse.file.FuseFileEntry
-
- getPath() - Method in class alluxio.fuse.OpenFileEntry
-
- getPath() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional string path = 1;
- getPath() - Method in class alluxio.grpc.CheckAccessPRequest
-
optional string path = 1;
- getPath() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
-
optional string path = 1;
- getPath() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
the root of the subtree to check
- getPath() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
the root of the subtree to check
- getPath() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
-
the root of the subtree to check
- getPath() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
the path of the file
- getPath() - Method in class alluxio.grpc.CompleteFilePRequest
-
the path of the file
- getPath() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
-
the path of the file
- getPath() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
the path of the directory
- getPath() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
the path of the directory
- getPath() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
-
the path of the directory
- getPath() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
the path of the file
- getPath() - Method in class alluxio.grpc.CreateFilePRequest
-
the path of the file
- getPath() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
-
the path of the file
- getPath() - Method in class alluxio.grpc.DeletePRequest.Builder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.DeletePRequest
-
the path of the file or directory
- getPath() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional string path = 1;
- getPath() - Method in class alluxio.grpc.ExistsPRequest
-
optional string path = 1;
- getPath() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
-
optional string path = 1;
- getPath() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string path = 3;
- getPath() - Method in class alluxio.grpc.FileInfo
-
optional string path = 3;
- getPath() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string path = 3;
- getPath() - Method in class alluxio.grpc.FreePRequest.Builder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.FreePRequest
-
the path of the file or directory
- getPath() - Method in interface alluxio.grpc.FreePRequestOrBuilder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
optional string path = 1;
- getPath() - Method in class alluxio.grpc.GetFilePathPResponse
-
optional string path = 1;
- getPath() - Method in interface alluxio.grpc.GetFilePathPResponseOrBuilder
-
optional string path = 1;
- getPath() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
the path of the file
- getPath() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
the path of the file
- getPath() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
-
the path of the file
- getPath() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.GetStatusPRequest
-
the path of the file or directory
- getPath() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.JobDescription.Builder
-
optional string path = 2;
- getPath() - Method in class alluxio.grpc.JobDescription
-
optional string path = 2;
- getPath() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
-
optional string path = 2;
- getPath() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
the path of the file or directory
- getPath() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.ListStatusPRequest
-
the path of the file or directory
- getPath() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
required string path = 1;
- getPath() - Method in class alluxio.grpc.NeedsSyncRequest
-
required string path = 1;
- getPath() - Method in interface alluxio.grpc.NeedsSyncRequestOrBuilder
-
required string path = 1;
- getPath() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional string path = 1;
- getPath() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
optional string path = 1;
- getPath() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
-
optional string path = 1;
- getPath() - Method in class alluxio.grpc.RenamePRequest.Builder
-
the source path of the file or directory
- getPath() - Method in class alluxio.grpc.RenamePRequest
-
the source path of the file or directory
- getPath() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
-
the source path of the file or directory
- getPath() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
the path of the file
- getPath() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
the path of the file
- getPath() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
-
the path of the file
- getPath() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.SetAclPRequest
-
the path of the file or directory
- getPath() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the path of the file or directory
- getPath() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
the path of the file
- getPath() - Method in class alluxio.grpc.SetAttributePRequest
-
the path of the file
- getPath() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
-
the path of the file
- getPath() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional string path = 1;
- getPath() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
optional string path = 1;
- getPath() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
optional string path = 1;
- getPath() - Method in class alluxio.job.JobDescription
-
- getPath() - Method in class alluxio.job.LoadJobRequest
-
- getPath(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getPath(long) - Method in interface alluxio.master.file.FileSystemMaster
-
Gets the path of a file with the given id.
- getPath(long) - Method in class alluxio.master.file.meta.FileSystemMasterView
-
Gets the path of a file with the given id.
- getPath(long) - Method in class alluxio.master.file.meta.InodeTree
-
Returns the path for a particular inode id.
- getPath(InodeView) - Method in class alluxio.master.file.meta.InodeTree
-
Returns the path for a particular inode.
- getPath() - Method in class alluxio.master.file.meta.LockingScheme
-
- getPath() - Method in class alluxio.master.job.DoraLoadJob
-
Get load file path.
- getPath() - Method in class alluxio.master.job.LoadJob
-
Get load file path.
- getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
optional string path = 1;
- getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
-
optional string path = 1;
- getPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateResponseOrBuilder
-
optional string path = 1;
- getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
optional string path = 1;
- getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
-
optional string path = 1;
- getPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenResponseOrBuilder
-
optional string path = 1;
- getPath() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional string path = 5;
- getPath() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
optional string path = 5;
- getPath() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
optional string path = 5;
- getPath() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string path = 17;
- getPath() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string path = 17;
- getPath() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string path = 17;
- getPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string path = 25;
- getPath() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string path = 25;
- getPath() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string path = 25;
- getPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string path = 6;
- getPath() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional string path = 6;
- getPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional string path = 6;
- getPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string path = 12;
- getPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional string path = 12;
- getPath() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional string path = 12;
- getPath() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
optional string path = 1;
- getPath() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
optional string path = 1;
- getPath() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
-
optional string path = 1;
- getPath() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
optional string path = 1;
- getPath() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
-
optional string path = 1;
- getPath() - Method in interface alluxio.proto.journal.Meta.RemovePathPropertiesEntryOrBuilder
-
optional string path = 1;
- getPath() - Method in class alluxio.uri.StandardURI
-
- getPath() - Method in interface alluxio.uri.URI
-
- getPath() - Method in class alluxio.wire.FileInfo
-
- getPath() - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Gets path.
- getPath() - Method in interface alluxio.worker.block.meta.BlockMeta
-
- getPath() - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- getPath() - Method in class alluxio.worker.dora.OpenFileHandle
-
Get path of this handle.
- getPathBytes() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.grpc.CheckAccessPRequest
-
optional string path = 1;
- getPathBytes() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
the root of the subtree to check
- getPathBytes() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
the root of the subtree to check
- getPathBytes() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
-
the root of the subtree to check
- getPathBytes() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
the path of the file
- getPathBytes() - Method in class alluxio.grpc.CompleteFilePRequest
-
the path of the file
- getPathBytes() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
-
the path of the file
- getPathBytes() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
the path of the directory
- getPathBytes() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
the path of the directory
- getPathBytes() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
-
the path of the directory
- getPathBytes() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
the path of the file
- getPathBytes() - Method in class alluxio.grpc.CreateFilePRequest
-
the path of the file
- getPathBytes() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
-
the path of the file
- getPathBytes() - Method in class alluxio.grpc.DeletePRequest.Builder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.DeletePRequest
-
the path of the file or directory
- getPathBytes() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.grpc.ExistsPRequest
-
optional string path = 1;
- getPathBytes() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string path = 3;
- getPathBytes() - Method in class alluxio.grpc.FileInfo
-
optional string path = 3;
- getPathBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string path = 3;
- getPathBytes() - Method in class alluxio.grpc.FreePRequest.Builder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.FreePRequest
-
the path of the file or directory
- getPathBytes() - Method in interface alluxio.grpc.FreePRequestOrBuilder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.grpc.GetFilePathPResponse
-
optional string path = 1;
- getPathBytes() - Method in interface alluxio.grpc.GetFilePathPResponseOrBuilder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
the path of the file
- getPathBytes() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
the path of the file
- getPathBytes() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
-
the path of the file
- getPathBytes() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.GetStatusPRequest
-
the path of the file or directory
- getPathBytes() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.JobDescription.Builder
-
optional string path = 2;
- getPathBytes() - Method in class alluxio.grpc.JobDescription
-
optional string path = 2;
- getPathBytes() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
-
optional string path = 2;
- getPathBytes() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
the path of the file or directory
- getPathBytes() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.ListStatusPRequest
-
the path of the file or directory
- getPathBytes() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
required string path = 1;
- getPathBytes() - Method in class alluxio.grpc.NeedsSyncRequest
-
required string path = 1;
- getPathBytes() - Method in interface alluxio.grpc.NeedsSyncRequestOrBuilder
-
required string path = 1;
- getPathBytes() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
optional string path = 1;
- getPathBytes() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.grpc.RenamePRequest.Builder
-
the source path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.RenamePRequest
-
the source path of the file or directory
- getPathBytes() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
-
the source path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
the path of the file
- getPathBytes() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
the path of the file
- getPathBytes() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
-
the path of the file
- getPathBytes() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.SetAclPRequest
-
the path of the file or directory
- getPathBytes() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the path of the file or directory
- getPathBytes() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
the path of the file
- getPathBytes() - Method in class alluxio.grpc.SetAttributePRequest
-
the path of the file
- getPathBytes() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
-
the path of the file
- getPathBytes() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
optional string path = 1;
- getPathBytes() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
-
optional string path = 1;
- getPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateResponseOrBuilder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
-
optional string path = 1;
- getPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenResponseOrBuilder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional string path = 5;
- getPathBytes() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
optional string path = 5;
- getPathBytes() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
optional string path = 5;
- getPathBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string path = 17;
- getPathBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string path = 17;
- getPathBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string path = 17;
- getPathBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string path = 25;
- getPathBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string path = 25;
- getPathBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string path = 25;
- getPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string path = 6;
- getPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional string path = 6;
- getPathBytes() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional string path = 6;
- getPathBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string path = 12;
- getPathBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional string path = 12;
- getPathBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional string path = 12;
- getPathBytes() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
optional string path = 1;
- getPathBytes() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
optional string path = 1;
- getPathBytes() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
-
optional string path = 1;
- getPathBytes() - Method in interface alluxio.proto.journal.Meta.RemovePathPropertiesEntryOrBuilder
-
optional string path = 1;
- getPathComponents(String) - Static method in class alluxio.util.io.PathUtils
-
Gets the path components of the given path.
- getPathConf() - Method in class alluxio.wire.Configuration
-
- getPathConfHash() - Method in class alluxio.wire.Configuration
-
- getPathConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string pathConfigHash = 2;
- getPathConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse
-
optional string pathConfigHash = 2;
- getPathConfigHash() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
-
optional string pathConfigHash = 2;
- getPathConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string pathConfigHash = 4;
- getPathConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse
-
optional string pathConfigHash = 4;
- getPathConfigHash() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
optional string pathConfigHash = 4;
- getPathConfigHash() - Method in class alluxio.wire.ConfigHash
-
- getPathConfigHash() - Method in class alluxio.wire.WorkerWebUIConfiguration
-
- getPathConfigHashBytes() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string pathConfigHash = 2;
- getPathConfigHashBytes() - Method in class alluxio.grpc.GetConfigHashPResponse
-
optional string pathConfigHash = 2;
- getPathConfigHashBytes() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
-
optional string pathConfigHash = 2;
- getPathConfigHashBytes() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string pathConfigHash = 4;
- getPathConfigHashBytes() - Method in class alluxio.grpc.GetConfigurationPResponse
-
optional string pathConfigHash = 4;
- getPathConfigHashBytes() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
optional string pathConfigHash = 4;
- getPathConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional int64 pathConfigLastUpdateTime = 6;
- getPathConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse
-
optional int64 pathConfigLastUpdateTime = 6;
- getPathConfigLastUpdateTime() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
optional int64 pathConfigLastUpdateTime = 6;
- getPathConfigLastUpdateTime() - Method in class alluxio.wire.ConfigHash
-
- getPathConfigLastUpdateTime() - Method in class alluxio.wire.WorkerWebUIConfiguration
-
- getPathConfigLastUpdateTimeText() - Method in class alluxio.wire.ConfigHash
-
- getPathConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
Deprecated.
- getPathConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse
-
Deprecated.
- getPathConfigs() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
Deprecated.
- getPathConfigsCount() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- getPathConfigsCount() - Method in class alluxio.grpc.GetConfigurationPResponse
-
- getPathConfigsCount() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- getPathConfigsMap() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- getPathConfigsMap() - Method in class alluxio.grpc.GetConfigurationPResponse
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- getPathConfigsMap() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- getPathConfigsOrDefault(String, ConfigProperties) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- getPathConfigsOrDefault(String, ConfigProperties) - Method in class alluxio.grpc.GetConfigurationPResponse
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- getPathConfigsOrDefault(String, ConfigProperties) - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- getPathConfigsOrThrow(String) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- getPathConfigsOrThrow(String) - Method in class alluxio.grpc.GetConfigurationPResponse
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- getPathConfigsOrThrow(String) - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
- getPathConfLastUpdateTime() - Method in class alluxio.wire.Configuration
-
- getPathInfos() - Method in class alluxio.wire.MasterWebUIBrowse
-
Get path infos ui file info [ ].
- getPathInodeNames(InodeView) - Method in class alluxio.master.file.meta.InodeTree
-
Computes the path components for the given inode view.
- getPathInodeNames(long) - Method in class alluxio.master.file.meta.InodeTree
-
Computes the path components for the given inode id.
- getPathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- getPathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- getPathProperties() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- getPathPropertiesBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- getPathPropertiesOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- getPathPropertiesOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- getPathPropertiesOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- getPathResolverCache(AlluxioConfiguration, FuseOptions) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Gets the cache for resolving FUSE path into
AlluxioURI
.
- getPathStatus(FileSystem, AlluxioURI) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Gets the path status.
- getPathWithoutScheme(Path) - Static method in class alluxio.hadoop.HadoopUtils
-
Given a Path
path, it returns the path component of its URI, which has the form
scheme://authority/path.
- getPattern() - Method in class alluxio.master.file.meta.LockingScheme
-
- getPattern() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
optional string pattern = 2;
- getPattern() - Method in class alluxio.proto.journal.Job.FileFilter
-
optional string pattern = 2;
- getPattern() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
-
optional string pattern = 2;
- getPatternBytes() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
optional string pattern = 2;
- getPatternBytes() - Method in class alluxio.proto.journal.Job.FileFilter
-
optional string pattern = 2;
- getPatternBytes() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
-
optional string pattern = 2;
- getPayload() - Method in class alluxio.collections.DirectedAcyclicGraphNode
-
Gets the payload of the node.
- getPayloadDataBuffer() - Method in class alluxio.network.protocol.RPCMessage
-
Returns the data buffer of the payload.
- getPayloadDataBuffer() - Method in class alluxio.network.protocol.RPCProtoMessage
-
- getPeerId(InetSocketAddress) - Static method in class alluxio.master.journal.raft.RaftJournalUtils
-
Gets the raft peer id.
- getPeerId(String, int) - Static method in class alluxio.master.journal.raft.RaftJournalUtils
-
Gets the raft peer id.
- getPendingCount() - Method in class alluxio.concurrent.jsr.CountedCompleter
-
Returns the current pending count.
- getPercentAvailable() - Method in class alluxio.wire.JournalDiskInfo
-
- getPermanentFileName(String) - Static method in class alluxio.util.io.PathUtils
-
- getPermission(LockedInodePath) - Method in class alluxio.master.file.DefaultPermissionChecker
-
- getPermission(String, List<String>) - Method in class alluxio.master.file.meta.Inode
-
- getPermission(String, List<String>) - Method in interface alluxio.master.file.meta.InodeView
-
Gets the permitted actions for a user.
- getPermission(String, List<String>) - Method in class alluxio.master.file.meta.MutableInode
-
- getPermission(LockedInodePath) - Method in interface alluxio.master.file.PermissionChecker
-
Gets the permission to access inodePath for the current client user.
- getPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 permission = 8;
- getPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int32 permission = 8;
- getPermission() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int32 permission = 8;
- getPermission(String, List<String>) - Method in class alluxio.security.authorization.AccessControlList
-
Gets the permitted actions for a user.
- getPermissionError() - Method in class alluxio.wire.MasterWebUIData
-
Gets permission error.
- getPermissions() - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- getPermissions() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- getPermissions() - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- getPermissions() - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Permissions for the mounted bucket.
- getPermissions() - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- getPermissions() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- getPermissions() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getPersist() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional bool persist = 2;
- getPersist() - Method in class alluxio.grpc.RenamePOptions
-
optional bool persist = 2;
- getPersist() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
-
optional bool persist = 2;
- getPersist() - Method in class alluxio.master.file.contexts.RenameContext
-
- getPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- getPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- getPersistDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- getPersistDirectoryBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- getPersistDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- getPersistDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- getPersistDirectoryOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- getPersisted() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool persisted = 12;
- getPersisted() - Method in class alluxio.grpc.FileInfo
-
optional bool persisted = 12;
- getPersisted() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool persisted = 12;
- getPersisted() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool persisted = 2;
- getPersisted() - Method in class alluxio.grpc.SetAttributePOptions
-
optional bool persisted = 2;
- getPersisted() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional bool persisted = 2;
- getPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional bool persisted = 5;
- getPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional bool persisted = 5;
- getPersisted() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional bool persisted = 5;
- getPersistedFileFingerprints(int) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprints(int) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprints(int) - Method in interface alluxio.grpc.FileSystemHeartbeatPOptionsOrBuilder
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprintsBytes(int) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprintsBytes(int) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprintsBytes(int) - Method in interface alluxio.grpc.FileSystemHeartbeatPOptionsOrBuilder
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprintsCount() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprintsCount() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprintsCount() - Method in interface alluxio.grpc.FileSystemHeartbeatPOptionsOrBuilder
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprintsList() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprintsList() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
repeated string persistedFileFingerprints = 1;
- getPersistedFileFingerprintsList() - Method in interface alluxio.grpc.FileSystemHeartbeatPOptionsOrBuilder
-
repeated string persistedFileFingerprints = 1;
- getPersistedFiles(int) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
the list of persisted files
- getPersistedFiles(int) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
the list of persisted files
- getPersistedFiles(int) - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
-
the list of persisted files
- getPersistedFilesCount() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
the list of persisted files
- getPersistedFilesCount() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
the list of persisted files
- getPersistedFilesCount() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
-
the list of persisted files
- getPersistedFilesList() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
the list of persisted files
- getPersistedFilesList() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
the list of persisted files
- getPersistedFilesList() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
-
the list of persisted files
- getPersistenceState() - Method in class alluxio.client.file.URIStatus
-
- getPersistenceState() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string persistenceState = 19;
- getPersistenceState() - Method in class alluxio.grpc.FileInfo
-
optional string persistenceState = 19;
- getPersistenceState() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string persistenceState = 19;
- getPersistenceState(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getPersistenceState(long) - Method in interface alluxio.master.file.FileSystemMaster
-
Returns the persistence state for a file id.
- getPersistenceState() - Method in class alluxio.master.file.meta.Inode
-
- getPersistenceState() - Method in interface alluxio.master.file.meta.InodeView
-
- getPersistenceState() - Method in class alluxio.master.file.meta.MutableInode
-
- getPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string persistence_state = 4;
- getPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string persistence_state = 4;
- getPersistenceState() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string persistence_state = 4;
- getPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string persistence_state = 4;
- getPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string persistence_state = 4;
- getPersistenceState() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string persistence_state = 4;
- getPersistenceState() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string persistence_state = 4;
- getPersistenceState() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string persistence_state = 4;
- getPersistenceState() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string persistence_state = 4;
- getPersistenceState() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persistence_state = 8;
- getPersistenceState() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string persistence_state = 8;
- getPersistenceState() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string persistence_state = 8;
- getPersistenceState() - Method in class alluxio.util.webui.UIFileInfo
-
Gets persistence state.
- getPersistenceState() - Method in class alluxio.wire.FileInfo
-
- getPersistenceStateBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string persistenceState = 19;
- getPersistenceStateBytes() - Method in class alluxio.grpc.FileInfo
-
optional string persistenceState = 19;
- getPersistenceStateBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string persistenceState = 19;
- getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string persistence_state = 4;
- getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string persistence_state = 4;
- getPersistenceStateBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string persistence_state = 4;
- getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string persistence_state = 4;
- getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string persistence_state = 4;
- getPersistenceStateBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string persistence_state = 4;
- getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string persistence_state = 4;
- getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string persistence_state = 4;
- getPersistenceStateBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string persistence_state = 4;
- getPersistenceStateBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persistence_state = 8;
- getPersistenceStateBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string persistence_state = 8;
- getPersistenceStateBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string persistence_state = 8;
- getPersistenceWaitTime() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getPersistenceWaitTime() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int64 persistenceWaitTime = 10;
- getPersistenceWaitTime() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int64 persistenceWaitTime = 10;
- getPersistenceWaitTime() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int64 persistenceWaitTime = 10;
- getPersistenceWaitTime() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional int64 persistenceWaitTime = 2;
- getPersistenceWaitTime() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
optional int64 persistenceWaitTime = 2;
- getPersistenceWaitTime() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
-
optional int64 persistenceWaitTime = 2;
- getPersistenceWaitTime() - Method in class alluxio.master.file.contexts.ScheduleAsyncPersistenceContext
-
- getPersistentTmpPath(AlluxioConfiguration, String) - Static method in class alluxio.util.io.PathUtils
-
Get temp path for async persistence job.
- getPersistFiles(int) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFiles(int) - Method in class alluxio.grpc.PersistCommandOptions
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFiles(int) - Method in interface alluxio.grpc.PersistCommandOptionsOrBuilder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesBuilder(int) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesBuilderList() - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesCount() - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesCount() - Method in class alluxio.grpc.PersistCommandOptions
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesCount() - Method in interface alluxio.grpc.PersistCommandOptionsOrBuilder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesList() - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesList() - Method in class alluxio.grpc.PersistCommandOptions
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesList() - Method in interface alluxio.grpc.PersistCommandOptionsOrBuilder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesOrBuilder(int) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesOrBuilder(int) - Method in class alluxio.grpc.PersistCommandOptions
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesOrBuilder(int) - Method in interface alluxio.grpc.PersistCommandOptionsOrBuilder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesOrBuilderList() - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesOrBuilderList() - Method in class alluxio.grpc.PersistCommandOptions
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistFilesOrBuilderList() - Method in interface alluxio.grpc.PersistCommandOptionsOrBuilder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- getPersistJobId() - Method in class alluxio.master.file.meta.InodeFile
-
- getPersistJobId() - Method in interface alluxio.master.file.meta.InodeFileView
-
- getPersistJobId() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getPersistJobId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 persist_job_id = 22;
- getPersistJobId() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 persist_job_id = 22;
- getPersistJobId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 persist_job_id = 22;
- getPersistJobId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 persistJobId = 11;
- getPersistJobId() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int64 persistJobId = 11;
- getPersistJobId() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int64 persistJobId = 11;
- getPersistJobId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 persist_job_id = 10;
- getPersistJobId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int64 persist_job_id = 10;
- getPersistJobId() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int64 persist_job_id = 10;
- getPersistJobId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
Used for recovering in-progress file persist jobs on master start.
- getPersistJobId() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
Used for recovering in-progress file persist jobs on master start.
- getPersistJobId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
Used for recovering in-progress file persist jobs on master start.
- getPersistJobTempUfsPath() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persist_job_temp_ufs_path = 24;
- getPersistJobTempUfsPath() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string persist_job_temp_ufs_path = 24;
- getPersistJobTempUfsPath() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string persist_job_temp_ufs_path = 24;
- getPersistJobTempUfsPathBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persist_job_temp_ufs_path = 24;
- getPersistJobTempUfsPathBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string persist_job_temp_ufs_path = 24;
- getPersistJobTempUfsPathBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string persist_job_temp_ufs_path = 24;
- getPersistOptions() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- getPersistOptions() - Method in class alluxio.grpc.FileSystemCommandOptions
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- getPersistOptions() - Method in interface alluxio.grpc.FileSystemCommandOptionsOrBuilder
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- getPersistOptions() - Method in class alluxio.wire.FileSystemCommandOptions
-
- getPersistOptionsBuilder() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- getPersistOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- getPersistOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemCommandOptions
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- getPersistOptionsOrBuilder() - Method in interface alluxio.grpc.FileSystemCommandOptionsOrBuilder
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- getPhysicalStores() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getPhysicalStores() - Method in class alluxio.underfs.BaseUnderFileSystem
-
- getPhysicalStores() - Method in interface alluxio.underfs.UnderFileSystem
-
- getPhysicalStores() - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getPhysicalUfsState(List<String>) - Method in class alluxio.underfs.MasterUfsManager
-
Get the physical ufs operation modes for the
UnderFileSystem
under the given Mount
table resolution.
- getPinIdList() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getPinIdList() - Method in interface alluxio.master.file.FileSystemMaster
-
- getPinIdSet() - Method in class alluxio.master.file.meta.InodeTree
-
- getPinList() - Method in class alluxio.worker.file.FileSystemMasterClient
-
- getPinned() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool pinned = 10;
- getPinned() - Method in class alluxio.grpc.FileInfo
-
optional bool pinned = 10;
- getPinned() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool pinned = 10;
- getPinned() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool pinned = 1;
- getPinned() - Method in class alluxio.grpc.SetAttributePOptions
-
optional bool pinned = 1;
- getPinned() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional bool pinned = 1;
- getPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool pinned = 5;
- getPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional bool pinned = 5;
- getPinned() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional bool pinned = 5;
- getPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool pinned = 5;
- getPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional bool pinned = 5;
- getPinned() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional bool pinned = 5;
- getPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional bool pinned = 3;
- getPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional bool pinned = 3;
- getPinned() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional bool pinned = 3;
- getPinned() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool pinned = 5;
- getPinned() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional bool pinned = 5;
- getPinned() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional bool pinned = 5;
- getPinnedFileIds(GetPinnedFileIdsPRequest, StreamObserver<GetPinnedFileIdsPResponse>) - Method in interface alluxio.grpc.FileSystemMasterWorkerServiceGrpc.AsyncService
-
Returns the set of pinned file ids.
- getPinnedFileIds(GetPinnedFileIdsPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub
-
Returns the set of pinned file ids.
- getPinnedFileIds(GetPinnedFileIdsPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub
-
Returns the set of pinned file ids.
- getPinnedFileIds(GetPinnedFileIdsPRequest, StreamObserver<GetPinnedFileIdsPResponse>) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub
-
Returns the set of pinned file ids.
- getPinnedFileIds(int) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
TODO(adit): set replacement?
- getPinnedFileIds(int) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
-
TODO(adit): set replacement?
- getPinnedFileIds(int) - Method in interface alluxio.grpc.GetPinnedFileIdsPResponseOrBuilder
-
TODO(adit): set replacement?
- getPinnedFileIds(GetPinnedFileIdsPRequest, StreamObserver<GetPinnedFileIdsPResponse>) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
-
- getPinnedFileIdsCount() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
TODO(adit): set replacement?
- getPinnedFileIdsCount() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
-
TODO(adit): set replacement?
- getPinnedFileIdsCount() - Method in interface alluxio.grpc.GetPinnedFileIdsPResponseOrBuilder
-
TODO(adit): set replacement?
- getPinnedFileIdsList() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
TODO(adit): set replacement?
- getPinnedFileIdsList() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
-
TODO(adit): set replacement?
- getPinnedFileIdsList() - Method in interface alluxio.grpc.GetPinnedFileIdsPResponseOrBuilder
-
TODO(adit): set replacement?
- GetPinnedFileIdsPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPOptions
- GetPinnedFileIdsPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPOptions
- GetPinnedFileIdsPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetPinnedFileIdsPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPRequest
- GetPinnedFileIdsPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPRequest
- GetPinnedFileIdsPRequestOrBuilder - Interface in alluxio.grpc
-
- GetPinnedFileIdsPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPResponse
- GetPinnedFileIdsPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPResponse
- GetPinnedFileIdsPResponseOrBuilder - Interface in alluxio.grpc
-
- getPinnedInodeFileIds() - Method in class alluxio.master.file.meta.InodeTreePersistentState
-
- getPinnedMedia(int) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
repeated string pinnedMedia = 10;
- getPinnedMedia(int) - Method in class alluxio.grpc.SetAttributePOptions
-
repeated string pinnedMedia = 10;
- getPinnedMedia(int) - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
repeated string pinnedMedia = 10;
- getPinnedMediaBytes(int) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
repeated string pinnedMedia = 10;
- getPinnedMediaBytes(int) - Method in class alluxio.grpc.SetAttributePOptions
-
repeated string pinnedMedia = 10;
- getPinnedMediaBytes(int) - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
repeated string pinnedMedia = 10;
- getPinnedMediaCount() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
repeated string pinnedMedia = 10;
- getPinnedMediaCount() - Method in class alluxio.grpc.SetAttributePOptions
-
repeated string pinnedMedia = 10;
- getPinnedMediaCount() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
repeated string pinnedMedia = 10;
- getPinnedMediaList() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
repeated string pinnedMedia = 10;
- getPinnedMediaList() - Method in class alluxio.grpc.SetAttributePOptions
-
repeated string pinnedMedia = 10;
- getPinnedMediaList() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
repeated string pinnedMedia = 10;
- getPinnedMediumTypes() - Method in class alluxio.client.file.URIStatus
-
- getPinnedSize() - Method in class alluxio.master.file.meta.InodeTree
-
- getPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional bool pin_on_create = 9;
- getPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand
-
optional bool pin_on_create = 9;
- getPinOnCreate() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional bool pin_on_create = 9;
- getPlanInfo() - Method in class alluxio.master.job.plan.PlanCoordinator
-
- getPlanInfoWire(boolean) - Method in class alluxio.master.job.plan.PlanCoordinator
-
- getPluginMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
-
Builds metric registry name for plugin instance.
- getPoints() - Method in class alluxio.stress.worker.IOTaskResult
-
- getPoints() - Method in class alluxio.stress.worker.IOTaskSummary
-
- getPolicy() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicy() - Method in class alluxio.grpc.AddPolicyPResponse
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicy() - Method in interface alluxio.grpc.AddPolicyPResponseOrBuilder
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicy(int) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicy(int) - Method in class alluxio.grpc.ListPolicyPResponse
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicy(int) - Method in interface alluxio.grpc.ListPolicyPResponseOrBuilder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyBuilder() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyBuilder(int) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyBuilderList() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyCount() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyCount() - Method in class alluxio.grpc.ListPolicyPResponse
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyCount() - Method in interface alluxio.grpc.ListPolicyPResponseOrBuilder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyDefinition() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- getPolicyDefinition() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- getPolicyDefinition() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- getPolicyDefinitionBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- getPolicyDefinitionOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- getPolicyDefinitionOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- getPolicyDefinitionOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- getPolicyList() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyList() - Method in class alluxio.grpc.ListPolicyPResponse
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyList() - Method in interface alluxio.grpc.ListPolicyPResponseOrBuilder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyName() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional string policyName = 1;
- getPolicyName() - Method in class alluxio.grpc.AddPolicyPRequest
-
optional string policyName = 1;
- getPolicyName() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
-
optional string policyName = 1;
- getPolicyName() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string policyName = 1;
- getPolicyName() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional string policyName = 1;
- getPolicyName() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional string policyName = 1;
- getPolicyName() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional string policyName = 1;
- getPolicyName() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
optional string policyName = 1;
- getPolicyName() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
-
optional string policyName = 1;
- getPolicyName() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional string policyName = 1;
- getPolicyName() - Method in class alluxio.grpc.RemovePolicyPRequest
-
optional string policyName = 1;
- getPolicyName() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
-
optional string policyName = 1;
- getPolicyName() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
optional string policyName = 1;
- getPolicyName() - Method in class alluxio.grpc.TriggerPolicyRequest
-
optional string policyName = 1;
- getPolicyName() - Method in interface alluxio.grpc.TriggerPolicyRequestOrBuilder
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in class alluxio.grpc.AddPolicyPRequest
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in class alluxio.grpc.RemovePolicyPRequest
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in class alluxio.grpc.TriggerPolicyRequest
-
optional string policyName = 1;
- getPolicyNameBytes() - Method in interface alluxio.grpc.TriggerPolicyRequestOrBuilder
-
optional string policyName = 1;
- getPolicyOrBuilder() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyOrBuilder() - Method in class alluxio.grpc.AddPolicyPResponse
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyOrBuilder() - Method in interface alluxio.grpc.AddPolicyPResponseOrBuilder
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyOrBuilder(int) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyOrBuilder(int) - Method in class alluxio.grpc.ListPolicyPResponse
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyOrBuilder(int) - Method in interface alluxio.grpc.ListPolicyPResponseOrBuilder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyOrBuilderList() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyOrBuilderList() - Method in class alluxio.grpc.ListPolicyPResponse
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyOrBuilderList() - Method in interface alluxio.grpc.ListPolicyPResponseOrBuilder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- getPolicyRemove() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- getPolicyRemove() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- getPolicyRemove() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- getPolicyRemoveBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- getPolicyRemoveOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- getPolicyRemoveOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- getPolicyRemoveOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- getPolicyStatus(GetPolicyStatusPRequest, StreamObserver<GetPolicyStatusPResponse>) - Method in interface alluxio.grpc.PolicyMasterClientServiceGrpc.AsyncService
-
Gets the status of a policy
- getPolicyStatus(GetPolicyStatusPRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceBlockingStub
-
Gets the status of a policy
- getPolicyStatus(GetPolicyStatusPRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceFutureStub
-
Gets the status of a policy
- getPolicyStatus(GetPolicyStatusPRequest, StreamObserver<GetPolicyStatusPResponse>) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceStub
-
Gets the status of a policy
- GetPolicyStatusPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetPolicyStatusPOptions
- GetPolicyStatusPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetPolicyStatusPOptions
- GetPolicyStatusPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetPolicyStatusPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetPolicyStatusPRequest
- GetPolicyStatusPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetPolicyStatusPRequest
- GetPolicyStatusPRequestOrBuilder - Interface in alluxio.grpc
-
- GetPolicyStatusPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetPolicyStatusPResponse
- GetPolicyStatusPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.policy.GetPolicyStatusPResponse
- GetPolicyStatusPResponseOrBuilder - Interface in alluxio.grpc
-
- getPool() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
-
Returns the pool hosting the current thread, or null
if the current thread is executing
outside of any ForkJoinPool.
- getPool() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
-
Returns the pool hosting this thread.
- getPoolIndex() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
-
Returns the unique index number of this thread in its pool.
- getPoolSize() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns the number of worker threads that have started but not yet terminated.
- getPoolSize() - Method in class alluxio.master.AlluxioExecutorService
-
- getPort() - Method in class alluxio.cli.LogLevel.TargetInfo
-
- getPort() - Method in class alluxio.master.CoreMasterContext
-
- getPort() - Method in class alluxio.multi.process.PortCoordination.ReservedPort
-
- getPort() - Method in class alluxio.uri.SingleMasterAuthority
-
- getPort(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Gets the port number on a given service type.
- getPort() - Method in class alluxio.worker.http.HttpRequestUri
-
Get the port of the request URI.
- getPortKey() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
-
Gets the key of service port.
- getPortKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
-
Gets the key of service port.
- getPos() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
-
- getPos() - Method in class alluxio.client.file.PositionReadFileInStream
-
- getPos() - Method in class alluxio.client.file.ufs.UfsFileInStream
-
- getPos() - Method in class alluxio.file.SeekableBufferedInputStream
-
- getPos() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
-
- getPos() - Method in class alluxio.hadoop.BaseHdfsFileInputStream
-
- getPos() - Method in interface alluxio.Positioned
-
- getPos() - Method in class alluxio.underfs.cephfs.CephInputStream
-
Gets the current position of the stream.
- getPos() - Method in class alluxio.underfs.cephfs.CephSeekableInputStream
-
- getPos() - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
-
- getPos() - Method in class alluxio.underfs.hdfs.HdfsUnderFileInputStream
-
- getPos() - Method in class alluxio.underfs.s3a.S3AInputStream
-
- getPos() - Method in class alluxio.worker.dora.OpenFileHandle
-
Get write position of the out stream in this handle.
- getPos() - Method in class alluxio.worker.grpc.WriteRequestContext
-
- getPosition() - Method in class alluxio.worker.block.io.BlockWriter
-
- getPosition() - Method in class alluxio.worker.dora.PagedFileWriter
-
- getPositionShort() - Method in class alluxio.client.file.options.InStreamOptions
-
- getPositionShort() - Method in class alluxio.grpc.ReadRequest.Builder
-
Is position read to a small buffer
- getPositionShort() - Method in class alluxio.grpc.ReadRequest
-
Is position read to a small buffer
- getPositionShort() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
Is position read to a small buffer
- getPositionShort() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
is position short or not, used for HDFS performance optimization.
- getPositionShort() - Method in class alluxio.grpc.UfsReadOptions
-
is position short or not, used for HDFS performance optimization.
- getPositionShort() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
-
is position short or not, used for HDFS performance optimization.
- getPositionShort() - Method in class alluxio.underfs.options.OpenOptions
-
- getPosReceived() - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- getPossibleMountPoints(String) - Static method in class alluxio.util.io.PathUtils
-
Returns the list of possible mount points of the given path.
- getPosToQueue() - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- getPosToQueue() - Method in class alluxio.worker.netty.ReadRequestContext
-
- getPosToQueue() - Method in class alluxio.worker.netty.WriteRequestContext
-
- getPosToWrite() - Method in class alluxio.worker.netty.ReadRequestContext
-
- getPosToWrite() - Method in class alluxio.worker.netty.WriteRequestContext
-
- getPreferredWorker() - Method in class alluxio.cli.fs.command.FileLocation
-
Get the preferred worker.
- getPreferredWorkers(List<BlockWorkerInfo>, String, int) - Method in class alluxio.client.file.dora.ConsistentHashPolicy
-
- getPreferredWorkers(List<BlockWorkerInfo>, String, int) - Method in class alluxio.client.file.dora.LocalWorkerPolicy
-
Finds a local worker from the available workers, matching by hostname.
- getPreferredWorkers(List<BlockWorkerInfo>, String, int) - Method in interface alluxio.client.file.dora.WorkerLocationPolicy
-
Find a specified number of workers following the logic defined by the policy.
- getPrefix() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Only match files with a given prefix.
- getPrefix() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Only match files with a given prefix.
- getPrefix() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Only match files with a given prefix.
- getPrefix() - Method in class alluxio.master.metastore.ReadOption
-
- getPrefix() - Method in class alluxio.s3.ListBucketOptions
-
- getPrefix() - Method in class alluxio.s3.ListBucketResult.CommonPrefix
-
- getPrefix() - Method in class alluxio.s3.ListBucketResult
-
- getPrefixBytes() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Only match files with a given prefix.
- getPrefixBytes() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Only match files with a given prefix.
- getPrefixBytes() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Only match files with a given prefix.
- getPreviousVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 previous_version = 9;
- getPreviousVersion() - Method in class alluxio.grpc.table.TableInfo
-
optional int64 previous_version = 9;
- getPreviousVersion() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional int64 previous_version = 9;
- getPrimaryGroupName(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
-
Gets the primary group name of a user.
- getPrimaryMasterAddress() - Method in class alluxio.client.block.AllMastersWorkerInfo
-
- getPrimaryMasterAddressCached(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
-
- getPrimaryMasterAddressCached(MasterInquireClient) - Method in interface alluxio.master.selectionpolicy.MasterSelectionPolicy
-
Get and cache the primary master address.
- getPrimaryMasterIndex(int) - Method in class alluxio.multi.process.MultiProcessCluster
-
Gets the index of the primary master.
- getPrimaryMasterInfo() - Method in class alluxio.wire.MasterWebUIMasters
-
Get info of the primary master.
- getPrimaryMasterWorkerInfo() - Method in class alluxio.client.block.AllMastersWorkerInfo
-
- getPrimaryRpcAddress() - Method in interface alluxio.master.MasterInquireClient
-
- getPrimaryRpcAddress() - Method in class alluxio.master.PollingMasterInquireClient
-
- getPrimaryRpcAddress() - Method in class alluxio.master.SingleMasterInquireClient
-
- getPrimaryRpcAddress() - Method in class alluxio.master.ZkMasterInquireClient
-
- getPrimarySelector() - Method in class alluxio.master.CoreMasterContext
-
- getPrimarySelector() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- getPrimarySelector() - Method in class alluxio.master.MasterContext
-
- getPrimarySelector() - Method in class alluxio.master.MasterProcess
-
- getPrintStream() - Method in class alluxio.cli.fsadmin.command.Context
-
- getPriority() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional int32 priority = 4;
- getPriority() - Method in class alluxio.grpc.QuorumServerInfo
-
optional int32 priority = 4;
- getPriority() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
-
optional int32 priority = 4;
- getPriority() - Method in class alluxio.scheduler.job.Task
-
- getProcessLocalWorker() - Method in class alluxio.client.file.FileSystemContext
-
Acquires the internal block worker as a gateway for worker internal clients to communicate
with the local worker directly without going through external RPC frameworks.
- getProgress(JobProgressReportFormat, boolean) - Method in class alluxio.master.job.CopyJob
-
- getProgress(JobProgressReportFormat, boolean) - Method in class alluxio.master.job.DoraLoadJob
-
- getProgress(JobProgressReportFormat, boolean) - Method in class alluxio.master.job.LoadJob
-
- getProgress(JobProgressReportFormat, boolean) - Method in class alluxio.master.job.MoveJob
-
- getProgress(JobProgressReportFormat, boolean) - Method in interface alluxio.scheduler.job.Job
-
Get job progress.
- getProgressPercentage() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional float progressPercentage = 9;
- getProgressPercentage() - Method in class alluxio.grpc.CmdSummary
-
optional float progressPercentage = 9;
- getProgressPercentage() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional float progressPercentage = 9;
- getProgressReport() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
optional string progressReport = 1;
- getProgressReport() - Method in class alluxio.grpc.GetJobProgressPResponse
-
optional string progressReport = 1;
- getProgressReport() - Method in interface alluxio.grpc.GetJobProgressPResponseOrBuilder
-
optional string progressReport = 1;
- getProgressReportBytes() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
optional string progressReport = 1;
- getProgressReportBytes() - Method in class alluxio.grpc.GetJobProgressPResponse
-
optional string progressReport = 1;
- getProgressReportBytes() - Method in interface alluxio.grpc.GetJobProgressPResponseOrBuilder
-
optional string progressReport = 1;
- getPromote() - Method in class alluxio.grpc.ReadRequest.Builder
-
Whether the block should be promoted before reading
- getPromote() - Method in class alluxio.grpc.ReadRequest
-
Whether the block should be promoted before reading
- getPromote() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
Whether the block should be promoted before reading
- getPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
optional bool promote = 2;
- getPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
optional bool promote = 2;
- getPromote() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
-
optional bool promote = 2;
- getPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
Whether the block should be promoted before reading
- getPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
Whether the block should be promoted before reading
- getPromote() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
Whether the block should be promoted before reading
- getProperties() - Method in class alluxio.conf.InstancedConfiguration
-
Return reference to mProperties.
- getProperties() - Method in class alluxio.conf.reference.DemoProperty
-
- getProperties() - Method in interface alluxio.conf.reference.ReferenceProperty
-
Get the reference properties.
- getProperties(int) - Method in class alluxio.grpc.ConfigProperties.Builder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getProperties(int) - Method in class alluxio.grpc.ConfigProperties
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getProperties(int) - Method in interface alluxio.grpc.ConfigPropertiesOrBuilder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getProperties(int) - Method in class alluxio.grpc.InconsistentProperties.Builder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getProperties(int) - Method in class alluxio.grpc.InconsistentProperties
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getProperties(int) - Method in interface alluxio.grpc.InconsistentPropertiesOrBuilder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getProperties() - Method in class alluxio.grpc.MountPointInfo.Builder
-
Deprecated.
- getProperties() - Method in class alluxio.grpc.MountPointInfo
-
Deprecated.
- getProperties() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
Deprecated.
- getProperties() - Method in class alluxio.grpc.MountPOptions.Builder
-
Deprecated.
- getProperties() - Method in class alluxio.grpc.MountPOptions
-
Deprecated.
- getProperties() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
Deprecated.
- getProperties() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
Deprecated.
- getProperties() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
Deprecated.
- getProperties() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
Deprecated.
- getProperties() - Method in class alluxio.grpc.UfsInfo.Builder
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- getProperties() - Method in class alluxio.grpc.UfsInfo
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- getProperties() - Method in interface alluxio.grpc.UfsInfoOrBuilder
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- getProperties() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
Deprecated.
- getProperties() - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
Deprecated.
- getProperties() - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
-
Deprecated.
- getProperties() - Method in class alluxio.master.meta.PathProperties.State
-
- getProperties(String) - Method in class alluxio.master.meta.PathProperties.State
-
- getProperties() - Method in class alluxio.master.meta.PathPropertiesView
-
- getProperties() - Method in class alluxio.metrics.MetricsConfig
-
- getProperties(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getProperties(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getProperties(int) - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getProperties() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
Deprecated.
- getProperties() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
Deprecated.
- getProperties() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
-
Deprecated.
- getProperties() - Method in class alluxio.util.webui.UIMountPointInfo
-
- getProperties() - Method in class alluxio.wire.MountPointInfo
-
- getPropertiesBuilder(int) - Method in class alluxio.grpc.ConfigProperties.Builder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesBuilder(int) - Method in class alluxio.grpc.InconsistentProperties.Builder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesBuilder() - Method in class alluxio.grpc.UfsInfo.Builder
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- getPropertiesBuilder(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesBuilderList() - Method in class alluxio.grpc.ConfigProperties.Builder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesBuilderList() - Method in class alluxio.grpc.InconsistentProperties.Builder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesBuilderList() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesCount() - Method in class alluxio.grpc.ConfigProperties.Builder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesCount() - Method in class alluxio.grpc.ConfigProperties
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesCount() - Method in interface alluxio.grpc.ConfigPropertiesOrBuilder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesCount() - Method in class alluxio.grpc.InconsistentProperties.Builder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesCount() - Method in class alluxio.grpc.InconsistentProperties
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesCount() - Method in interface alluxio.grpc.InconsistentPropertiesOrBuilder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesCount() - Method in class alluxio.grpc.MountPointInfo.Builder
-
- getPropertiesCount() - Method in class alluxio.grpc.MountPointInfo
-
- getPropertiesCount() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
map<string, string> properties = 6;
- getPropertiesCount() - Method in class alluxio.grpc.MountPOptions.Builder
-
- getPropertiesCount() - Method in class alluxio.grpc.MountPOptions
-
- getPropertiesCount() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
map<string, string> properties = 2;
- getPropertiesCount() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- getPropertiesCount() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
- getPropertiesCount() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
map<string, string> properties = 2;
- getPropertiesCount() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- getPropertiesCount() - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
- getPropertiesCount() - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
-
map<string, string> properties = 1;
- getPropertiesCount() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesCount() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesCount() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesCount() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- getPropertiesCount() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
- getPropertiesCount() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
-
map<string, string> properties = 2;
- getPropertiesList() - Method in class alluxio.grpc.ConfigProperties.Builder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesList() - Method in class alluxio.grpc.ConfigProperties
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesList() - Method in interface alluxio.grpc.ConfigPropertiesOrBuilder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesList() - Method in class alluxio.grpc.InconsistentProperties.Builder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesList() - Method in class alluxio.grpc.InconsistentProperties
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesList() - Method in interface alluxio.grpc.InconsistentPropertiesOrBuilder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesList() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesList() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesList() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesMap() - Method in class alluxio.grpc.MountPointInfo.Builder
-
map<string, string> properties = 6;
- getPropertiesMap() - Method in class alluxio.grpc.MountPointInfo
-
map<string, string> properties = 6;
- getPropertiesMap() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
map<string, string> properties = 6;
- getPropertiesMap() - Method in class alluxio.grpc.MountPOptions.Builder
-
map<string, string> properties = 2;
- getPropertiesMap() - Method in class alluxio.grpc.MountPOptions
-
map<string, string> properties = 2;
- getPropertiesMap() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
map<string, string> properties = 2;
- getPropertiesMap() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
map<string, string> properties = 2;
- getPropertiesMap() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
map<string, string> properties = 2;
- getPropertiesMap() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
map<string, string> properties = 2;
- getPropertiesMap() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
map<string, string> properties = 1;
- getPropertiesMap() - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
map<string, string> properties = 1;
- getPropertiesMap() - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
-
map<string, string> properties = 1;
- getPropertiesMap() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
map<string, string> properties = 2;
- getPropertiesMap() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
map<string, string> properties = 2;
- getPropertiesMap() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
-
map<string, string> properties = 2;
- getPropertiesOrBuilder(int) - Method in class alluxio.grpc.ConfigProperties.Builder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesOrBuilder(int) - Method in class alluxio.grpc.ConfigProperties
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesOrBuilder(int) - Method in interface alluxio.grpc.ConfigPropertiesOrBuilder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesOrBuilder(int) - Method in class alluxio.grpc.InconsistentProperties.Builder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesOrBuilder(int) - Method in class alluxio.grpc.InconsistentProperties
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesOrBuilder(int) - Method in interface alluxio.grpc.InconsistentPropertiesOrBuilder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesOrBuilder() - Method in class alluxio.grpc.UfsInfo.Builder
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- getPropertiesOrBuilder() - Method in class alluxio.grpc.UfsInfo
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- getPropertiesOrBuilder() - Method in interface alluxio.grpc.UfsInfoOrBuilder
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- getPropertiesOrBuilder(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesOrBuilder(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesOrBuilder(int) - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesOrBuilderList() - Method in class alluxio.grpc.ConfigProperties.Builder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesOrBuilderList() - Method in class alluxio.grpc.ConfigProperties
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesOrBuilderList() - Method in interface alluxio.grpc.ConfigPropertiesOrBuilder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- getPropertiesOrBuilderList() - Method in class alluxio.grpc.InconsistentProperties.Builder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesOrBuilderList() - Method in class alluxio.grpc.InconsistentProperties
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesOrBuilderList() - Method in interface alluxio.grpc.InconsistentPropertiesOrBuilder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- getPropertiesOrBuilderList() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesOrBuilderList() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesOrBuilderList() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.MountPointInfo.Builder
-
map<string, string> properties = 6;
- getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.MountPointInfo
-
map<string, string> properties = 6;
- getPropertiesOrDefault(String, String) - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
map<string, string> properties = 6;
- getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.MountPOptions.Builder
-
map<string, string> properties = 2;
- getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.MountPOptions
-
map<string, string> properties = 2;
- getPropertiesOrDefault(String, String) - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
map<string, string> properties = 2;
- getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
map<string, string> properties = 2;
- getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
map<string, string> properties = 2;
- getPropertiesOrDefault(String, String) - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
map<string, string> properties = 2;
- getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
map<string, string> properties = 1;
- getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
map<string, string> properties = 1;
- getPropertiesOrDefault(String, String) - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
-
map<string, string> properties = 1;
- getPropertiesOrDefault(String, String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
map<string, string> properties = 2;
- getPropertiesOrDefault(String, String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
map<string, string> properties = 2;
- getPropertiesOrDefault(String, String) - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
-
map<string, string> properties = 2;
- getPropertiesOrThrow(String) - Method in class alluxio.grpc.MountPointInfo.Builder
-
map<string, string> properties = 6;
- getPropertiesOrThrow(String) - Method in class alluxio.grpc.MountPointInfo
-
map<string, string> properties = 6;
- getPropertiesOrThrow(String) - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
map<string, string> properties = 6;
- getPropertiesOrThrow(String) - Method in class alluxio.grpc.MountPOptions.Builder
-
map<string, string> properties = 2;
- getPropertiesOrThrow(String) - Method in class alluxio.grpc.MountPOptions
-
map<string, string> properties = 2;
- getPropertiesOrThrow(String) - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
map<string, string> properties = 2;
- getPropertiesOrThrow(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
map<string, string> properties = 2;
- getPropertiesOrThrow(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
map<string, string> properties = 2;
- getPropertiesOrThrow(String) - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
map<string, string> properties = 2;
- getPropertiesOrThrow(String) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
map<string, string> properties = 1;
- getPropertiesOrThrow(String) - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
map<string, string> properties = 1;
- getPropertiesOrThrow(String) - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
-
map<string, string> properties = 1;
- getPropertiesOrThrow(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
map<string, string> properties = 2;
- getPropertiesOrThrow(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
map<string, string> properties = 2;
- getPropertiesOrThrow(String) - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
-
map<string, string> properties = 2;
- getPropertyCode() - Method in enum alluxio.grpc.GrpcNetworkGroup
-
- getProxyAddress() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- getProxyAddress() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- getProxyAddress() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- getProxyAddressBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- getProxyAddressOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- getProxyAddressOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- getProxyAddressOrBuilder() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- getProxyDownloadFileApiUrl() - Method in class alluxio.wire.MasterWebUIInit
-
Gets proxy download file api url.
- getProxyFor(InetSocketAddress) - Method in class alluxio.master.transport.GrpcMessagingProxy
-
- getProxyHeartbeatMethod() - Static method in class alluxio.grpc.MetaMasterProxyServiceGrpc
-
- getProxyProcess() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Gets the proxy process.
- getProxyStatuses(int) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatuses(int) - Method in class alluxio.grpc.ListProxyStatusPResponse
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatuses(int) - Method in interface alluxio.grpc.ListProxyStatusPResponseOrBuilder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesBuilder(int) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesBuilderList() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesCount() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesCount() - Method in class alluxio.grpc.ListProxyStatusPResponse
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesCount() - Method in interface alluxio.grpc.ListProxyStatusPResponseOrBuilder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesList() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesList() - Method in class alluxio.grpc.ListProxyStatusPResponse
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesList() - Method in interface alluxio.grpc.ListProxyStatusPResponseOrBuilder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesOrBuilder(int) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesOrBuilder(int) - Method in class alluxio.grpc.ListProxyStatusPResponse
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesOrBuilder(int) - Method in interface alluxio.grpc.ListProxyStatusPResponseOrBuilder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesOrBuilderList() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesOrBuilderList() - Method in class alluxio.grpc.ListProxyStatusPResponse
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getProxyStatusesOrBuilderList() - Method in interface alluxio.grpc.ListProxyStatusPResponseOrBuilder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- getQuery() - Method in class alluxio.uri.StandardURI
-
- getQuery() - Method in interface alluxio.uri.URI
-
- getQueryMap() - Method in class alluxio.AlluxioURI
-
Gets the map of query parameters.
- getQueryParameter(String) - Method in class alluxio.proxy.s3.S3Handler
-
retrieve given query parameter value.
- getQueryParameter(String) - Method in class alluxio.worker.s3.S3NettyHandler
-
retrieve given query parameter value.
- getQueuedSubmissionCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns an estimate of the number of tasks submitted to this pool that have not yet begun
executing.
- getQueuedTaskCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns an estimate of the total number of tasks currently held in queues by worker threads
(but not including tasks submitted to the pool that have not begun executing).
- getQueuedTaskCount() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
-
Returns an estimate of the number of tasks that have been forked by the current worker thread
but not yet executed.
- getQuiet() - Method in class alluxio.s3.DeleteObjectsRequest
-
- getQuietPeriodMs() - Method in class alluxio.master.journal.ufs.UfsJournal
-
- getQuorumInfo() - Method in interface alluxio.client.journal.JournalMasterClient
-
Quorum information for participating servers in journal.
- getQuorumInfo() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
-
- getQuorumInfo(GetQuorumInfoPRequest, StreamObserver<GetQuorumInfoPResponse>) - Method in interface alluxio.grpc.JournalMasterClientServiceGrpc.AsyncService
-
Gets list of server states in an embedded journal quorum.
- getQuorumInfo(GetQuorumInfoPRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub
-
Gets list of server states in an embedded journal quorum.
- getQuorumInfo(GetQuorumInfoPRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub
-
Gets list of server states in an embedded journal quorum.
- getQuorumInfo(GetQuorumInfoPRequest, StreamObserver<GetQuorumInfoPResponse>) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceStub
-
Gets list of server states in an embedded journal quorum.
- getQuorumInfo() - Method in class alluxio.master.journal.DefaultJournalMaster
-
- getQuorumInfo() - Method in interface alluxio.master.journal.JournalMaster
-
Quorum information for participating servers in journal.
- getQuorumInfo(GetQuorumInfoPRequest, StreamObserver<GetQuorumInfoPResponse>) - Method in class alluxio.master.journal.JournalMasterClientServiceHandler
-
- GetQuorumInfoPOptions - Class in alluxio.grpc
-
GetQuorumInfo API
- GetQuorumInfoPOptions.Builder - Class in alluxio.grpc
-
GetQuorumInfo API
- GetQuorumInfoPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetQuorumInfoPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetQuorumInfoPRequest
- GetQuorumInfoPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetQuorumInfoPRequest
- GetQuorumInfoPRequestOrBuilder - Interface in alluxio.grpc
-
- GetQuorumInfoPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetQuorumInfoPResponse
- GetQuorumInfoPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetQuorumInfoPResponse
- GetQuorumInfoPResponseOrBuilder - Interface in alluxio.grpc
-
- getQuorumServerInfoList() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
Used to get information of internal RAFT quorum.
- getQuota(CacheScope) - Method in class alluxio.client.quota.CacheQuota
-
- getRaftAddress(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated string raftAddress = 13;
- getRaftAddress(int) - Method in class alluxio.grpc.MasterInfo
-
repeated string raftAddress = 13;
- getRaftAddress(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated string raftAddress = 13;
- getRaftAddressBytes(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated string raftAddress = 13;
- getRaftAddressBytes(int) - Method in class alluxio.grpc.MasterInfo
-
repeated string raftAddress = 13;
- getRaftAddressBytes(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated string raftAddress = 13;
- getRaftAddressCount() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated string raftAddress = 13;
- getRaftAddressCount() - Method in class alluxio.grpc.MasterInfo
-
repeated string raftAddress = 13;
- getRaftAddressCount() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated string raftAddress = 13;
- getRaftAddressList() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated string raftAddress = 13;
- getRaftAddressList() - Method in class alluxio.grpc.MasterInfo
-
repeated string raftAddress = 13;
- getRaftAddressList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated string raftAddress = 13;
- getRaftJournal() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional bool raftJournal = 12;
- getRaftJournal() - Method in class alluxio.grpc.MasterInfo
-
optional bool raftJournal = 12;
- getRaftJournal() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional bool raftJournal = 12;
- getRaftJournalAddress() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get raft journal address.
- getRaftJournalDir(File) - Static method in class alluxio.master.journal.raft.RaftJournalUtils
-
Gets the raft journal dir.
- getRandomNonNegativeLong() - Static method in class alluxio.util.IdUtils
-
Generates a positive random number by zero-ing the sign bit.
- getRange() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.RangeSet range = 1;
- getRange() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.RangeSet range = 1;
- getRange() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.RangeSet range = 1;
- getRangeBuilder() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.RangeSet range = 1;
- getRangeOrBuilder() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.RangeSet range = 1;
- getRangeOrBuilder() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.RangeSet range = 1;
- getRangeOrBuilder() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.RangeSet range = 1;
- getRanges(int) - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRanges(int) - Method in class alluxio.grpc.table.RangeSet
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRanges(int) - Method in interface alluxio.grpc.table.RangeSetOrBuilder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesBuilder(int) - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesBuilderList() - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesCount() - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesCount() - Method in class alluxio.grpc.table.RangeSet
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesCount() - Method in interface alluxio.grpc.table.RangeSetOrBuilder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesList() - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesList() - Method in class alluxio.grpc.table.RangeSet
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesList() - Method in interface alluxio.grpc.table.RangeSetOrBuilder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesOrBuilder(int) - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesOrBuilder(int) - Method in class alluxio.grpc.table.RangeSet
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesOrBuilder(int) - Method in interface alluxio.grpc.table.RangeSetOrBuilder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesOrBuilderList() - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesOrBuilderList() - Method in class alluxio.grpc.table.RangeSet
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRangesOrBuilderList() - Method in interface alluxio.grpc.table.RangeSetOrBuilder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- getRawReadWriteLock(K) - Method in class alluxio.collections.LockPool
-
Get the raw readwrite lock from the pool.
- getRawResult() - Method in class alluxio.concurrent.jsr.CountedCompleter
-
Returns the result of the computation.
- getRawResult() - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Returns the result that would be returned by
ForkJoinTask.join()
, even if this task completed
abnormally, or
null
if this task is not known to have been completed.
- getRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool rawValue = 1;
- getRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions
-
optional bool rawValue = 1;
- getRawValue() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
-
optional bool rawValue = 1;
- getReadBlockMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getReader(boolean) - Method in class alluxio.master.journal.ufs.UfsJournal
-
- getReader() - Method in interface alluxio.master.journalv0.Journal
-
- getReader() - Method in class alluxio.master.journalv0.ufs.UfsJournal
-
- getReadOnly() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional bool readOnly = 5;
- getReadOnly() - Method in class alluxio.grpc.MountPointInfo
-
optional bool readOnly = 5;
- getReadOnly() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional bool readOnly = 5;
- getReadOnly() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional bool readOnly = 1;
- getReadOnly() - Method in class alluxio.grpc.MountPOptions
-
optional bool readOnly = 1;
- getReadOnly() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
optional bool readOnly = 1;
- getReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional bool readOnly = 3;
- getReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional bool readOnly = 3;
- getReadOnly() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional bool readOnly = 3;
- getReadOnly() - Method in class alluxio.wire.MountPointInfo
-
- getReadOnlyByteBuffer() - Method in class alluxio.grpc.ReadableDataBuffer
-
- getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
-
- getReadOnlyByteBuffer() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
-
Returns a
ByteBuffer
for read-only access to the data.
- getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
-
- getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
-
- getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
-
- getReadSpeedStat() - Method in class alluxio.stress.worker.IOTaskSummary
-
- getReadTableMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getReadType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.ReadPType readType = 1;
- getReadType() - Method in class alluxio.grpc.OpenFilePOptions
-
optional .alluxio.grpc.file.ReadPType readType = 1;
- getReadType() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.ReadPType readType = 1;
- getRealRange(long) - Method in class alluxio.s3.S3RangeSpec
-
Get real range of response.
- getRecentActivities(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivities(int) - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivities(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivities() - Method in class alluxio.job.wire.JobServiceSummary
-
- getRecentActivitiesBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesCount() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesCount() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesCount() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesList() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesOrBuilder(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentActivitiesOrBuilderList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- getRecentFailedJobs() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Get recent failed jobs.
- getRecentFailures(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailures(int) - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailures(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailures() - Method in class alluxio.job.wire.JobServiceSummary
-
- getRecentFailuresBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresCount() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresCount() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresCount() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresList() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresOrBuilder(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentFailuresOrBuilderList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- getRecentModifiedJobs() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Get recent modified jobs.
- getRecorder() - Method in class alluxio.master.file.contexts.MountContext
-
Gets the Recorder.
- getRecordStartMs() - Method in class alluxio.stress.client.ClientIOTaskResult
-
- getRecordStartMs() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- getRecordStartMs() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- getRecoverFailedOpen() - Method in class alluxio.underfs.options.OpenOptions
-
- getRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool recursive = 1;
- getRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional bool recursive = 1;
- getRecursive() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional bool recursive = 1;
- getRecursive() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool recursive = 2;
- getRecursive() - Method in class alluxio.grpc.CreateFilePOptions
-
optional bool recursive = 2;
- getRecursive() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional bool recursive = 2;
- getRecursive() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool recursive = 1;
- getRecursive() - Method in class alluxio.grpc.DeletePOptions
-
optional bool recursive = 1;
- getRecursive() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional bool recursive = 1;
- getRecursive() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional bool recursive = 1;
- getRecursive() - Method in class alluxio.grpc.FreePOptions
-
optional bool recursive = 1;
- getRecursive() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
-
optional bool recursive = 1;
- getRecursive() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional bool recursive = 4;
- getRecursive() - Method in class alluxio.grpc.ListStatusPOptions
-
optional bool recursive = 4;
- getRecursive() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
optional bool recursive = 4;
- getRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
whether to load metadata recursively
- getRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions
-
whether to load metadata recursively
- getRecursive() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
whether to load metadata recursively
- getRecursive() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional bool recursive = 2;
- getRecursive() - Method in class alluxio.grpc.SetAclPOptions
-
optional bool recursive = 2;
- getRecursive() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
-
optional bool recursive = 2;
- getRecursive() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool recursive = 6;
- getRecursive() - Method in class alluxio.grpc.SetAttributePOptions
-
optional bool recursive = 6;
- getRecursive() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional bool recursive = 6;
- getRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
Deprecated, we now write one journal entry per inode removed
- getRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
Deprecated, we now write one journal entry per inode removed
- getRecursive() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
Deprecated, we now write one journal entry per inode removed
- getRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional bool recursive = 5;
- getRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry
-
optional bool recursive = 5;
- getRecursive() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
optional bool recursive = 5;
- getRefCount() - Method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
-
- getReferenceCount() - Method in class alluxio.concurrent.ClientRWLock
-
- getReferenceSize() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
-
Returns the fixed size of an object reference in this JVM.
- getRefreshInterval() - Method in class alluxio.wire.MasterWebUIInit
-
Gets refresh interval.
- getRefreshInterval() - Method in class alluxio.wire.WorkerWebUIInit
-
Gets refresh interval.
- getRegisterCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- getRegisterCommand() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- getRegisterCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- getRegisterCommandBuilder() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- getRegisterCommandOrBuilder() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- getRegisterCommandOrBuilder() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- getRegisterCommandOrBuilder() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- getRegisteredServiceDetail(String) - Method in class alluxio.membership.ServiceDiscoveryRecipe
-
Get the registered service value as ByteBuffer.
- getRegisterJobWorkerMethod() - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
-
- GetRegisterLeasePOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetRegisterLeasePOptions
- GetRegisterLeasePOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetRegisterLeasePOptions
- GetRegisterLeasePOptionsOrBuilder - Interface in alluxio.grpc
-
- GetRegisterLeasePRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetRegisterLeasePRequest
- GetRegisterLeasePRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetRegisterLeasePRequest
- GetRegisterLeasePRequestOrBuilder - Interface in alluxio.grpc
-
- GetRegisterLeasePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetRegisterLeasePResponse
- GetRegisterLeasePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetRegisterLeasePResponse
- GetRegisterLeasePResponseOrBuilder - Interface in alluxio.grpc
-
- getRegisterMasterMethod() - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
-
- getRegisterMasterMethod() - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
-
- getRegisterWorkerMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
-
- getRegisterWorkerStreamMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
-
- getRegistry() - Method in class alluxio.master.MasterProcess
-
- getRemainingFields() - Method in class alluxio.worker.http.HttpRequestUri
-
Get the remaining fields of the request URI.
- getRemoteHostName() - Method in class alluxio.AbstractClient
-
- getRemoteHostName() - Method in interface alluxio.Client
-
- getRemoteServiceType() - Method in class alluxio.AbstractClient
-
- getRemoteServiceType() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getRemoteServiceType() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- getRemoteServiceType() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- getRemoteServiceType() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
-
- getRemoteServiceType() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
-
- getRemoteServiceType() - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
-
- getRemoteServiceType() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
-
- getRemoteServiceType() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getRemoteServiceType() - Method in class alluxio.master.file.FileSystemMasterClient
-
- getRemoteServiceType() - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
-
- getRemoteServiceType() - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
-
- getRemoteServiceType() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
-
- getRemoteServiceType() - Method in class alluxio.proxy.RetryHandlingMetaMasterProxyClient
-
- getRemoteServiceType() - Method in class alluxio.worker.block.BlockMasterClient
-
- getRemoteServiceType() - Method in class alluxio.worker.file.FileSystemMasterClient
-
- getRemoteServiceType() - Method in class alluxio.worker.job.RetryHandlingJobMasterClient
-
- getRemoteServiceVersion() - Method in class alluxio.AbstractClient
-
- getRemoteSockAddress() - Method in class alluxio.AbstractClient
-
- getRemoteSockAddress() - Method in interface alluxio.Client
-
- getRemovalMessage(String) - Static method in class alluxio.conf.PropertyKey
-
- getRemoveBlockMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getRemovedBlockIds(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the list of removed block ids
- getRemovedBlockIds(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the list of removed block ids
- getRemovedBlockIds(int) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the list of removed block ids
- getRemovedBlockIdsCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the list of removed block ids
- getRemovedBlockIdsCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the list of removed block ids
- getRemovedBlockIdsCount() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the list of removed block ids
- getRemovedBlockIdsList() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the list of removed block ids
- getRemovedBlockIdsList() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the list of removed block ids
- getRemovedBlockIdsList() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the list of removed block ids
- getRemovedBlocks() - Method in class alluxio.worker.block.BlockHeartbeatReport
-
Gets the list of blocks removed from this worker in the heartbeat this report represents.
- getRemoveDisabledWorkerMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getRemoveMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getRemoveMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getRemovePathConfigurationMethod() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
-
- getRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- getRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- getRemovePathProperties() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- getRemovePathPropertiesBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- getRemovePathPropertiesOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- getRemovePathPropertiesOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- getRemovePathPropertiesOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- getRemovePolicyMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
-
- getRemoveQuorumServerMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
-
- getRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- getRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- getRemoveSyncPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- getRemoveSyncPointBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- getRemoveSyncPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- getRemoveSyncPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- getRemoveSyncPointOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- getRename() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- getRename() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- getRename() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- getRenameBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- getRenameMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getRenameMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getRenameOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- getRenameOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- getRenameOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- getReplicaBlockCount() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets replica block count.
- getReplicationDurable() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getReplicationDurable() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationDurable = 6;
- getReplicationDurable() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int32 replicationDurable = 6;
- getReplicationDurable() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int32 replicationDurable = 6;
- getReplicationDurable() - Method in class alluxio.master.file.meta.InodeFile
-
- getReplicationDurable() - Method in interface alluxio.master.file.meta.InodeFileView
-
- getReplicationDurable() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getReplicationDurable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_durable = 24;
- getReplicationDurable() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int32 replication_durable = 24;
- getReplicationDurable() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int32 replication_durable = 24;
- getReplicationDurable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_durable = 20;
- getReplicationDurable() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int32 replication_durable = 20;
- getReplicationDurable() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int32 replication_durable = 20;
- getReplicationLimitedFileIds() - Method in class alluxio.master.file.meta.InodeTree
-
- getReplicationLimitedFileIds() - Method in class alluxio.master.file.meta.InodeTreePersistentState
-
- getReplicationMax() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getReplicationMax() - Method in class alluxio.client.file.URIStatus
-
- getReplicationMax() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationMax = 4;
- getReplicationMax() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int32 replicationMax = 4;
- getReplicationMax() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int32 replicationMax = 4;
- getReplicationMax() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 replicationMax = 29;
- getReplicationMax() - Method in class alluxio.grpc.FileInfo
-
optional int32 replicationMax = 29;
- getReplicationMax() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int32 replicationMax = 29;
- getReplicationMax() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional int32 replicationMax = 7;
- getReplicationMax() - Method in class alluxio.grpc.SetAttributePOptions
-
optional int32 replicationMax = 7;
- getReplicationMax() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional int32 replicationMax = 7;
- getReplicationMax() - Method in class alluxio.master.file.meta.InodeFile
-
- getReplicationMax() - Method in interface alluxio.master.file.meta.InodeFileView
-
- getReplicationMax() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getReplicationMax() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_max = 20;
- getReplicationMax() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int32 replication_max = 20;
- getReplicationMax() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int32 replication_max = 20;
- getReplicationMax() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 replication_max = 13;
- getReplicationMax() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int32 replication_max = 13;
- getReplicationMax() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int32 replication_max = 13;
- getReplicationMax() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int32 replication_max = 8;
- getReplicationMax() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int32 replication_max = 8;
- getReplicationMax() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int32 replication_max = 8;
- getReplicationMax() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_max = 21;
- getReplicationMax() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int32 replication_max = 21;
- getReplicationMax() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int32 replication_max = 21;
- getReplicationMax() - Method in class alluxio.wire.FileInfo
-
- getReplicationMin() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getReplicationMin() - Method in class alluxio.client.file.URIStatus
-
- getReplicationMin() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationMin = 5;
- getReplicationMin() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int32 replicationMin = 5;
- getReplicationMin() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int32 replicationMin = 5;
- getReplicationMin() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 replicationMin = 30;
- getReplicationMin() - Method in class alluxio.grpc.FileInfo
-
optional int32 replicationMin = 30;
- getReplicationMin() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int32 replicationMin = 30;
- getReplicationMin() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional int32 replicationMin = 8;
- getReplicationMin() - Method in class alluxio.grpc.SetAttributePOptions
-
optional int32 replicationMin = 8;
- getReplicationMin() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional int32 replicationMin = 8;
- getReplicationMin() - Method in class alluxio.master.file.meta.InodeFile
-
- getReplicationMin() - Method in interface alluxio.master.file.meta.InodeFileView
-
- getReplicationMin() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getReplicationMin() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_min = 21;
- getReplicationMin() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int32 replication_min = 21;
- getReplicationMin() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int32 replication_min = 21;
- getReplicationMin() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 replication_min = 14;
- getReplicationMin() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int32 replication_min = 14;
- getReplicationMin() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int32 replication_min = 14;
- getReplicationMin() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int32 replication_min = 9;
- getReplicationMin() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int32 replication_min = 9;
- getReplicationMin() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int32 replication_min = 9;
- getReplicationMin() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_min = 22;
- getReplicationMin() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int32 replication_min = 22;
- getReplicationMin() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int32 replication_min = 22;
- getReplicationMin() - Method in class alluxio.wire.FileInfo
-
- getReport() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- getReport() - Method in class alluxio.grpc.GetConfigReportPResponse
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- getReport() - Method in interface alluxio.grpc.GetConfigReportPResponseOrBuilder
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- getReport() - Method in interface alluxio.worker.block.BlockWorker
-
Gets a report for the periodic heartbeat to master.
- getReportBuilder() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- getReportOrBuilder() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- getReportOrBuilder() - Method in class alluxio.grpc.GetConfigReportPResponse
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- getReportOrBuilder() - Method in interface alluxio.grpc.GetConfigReportPResponseOrBuilder
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- getRequest() - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- getRequest() - Method in class alluxio.worker.grpc.WriteRequestContext
-
- getRequest() - Method in class alluxio.worker.netty.ReadRequestContext
-
- getRequest() - Method in class alluxio.worker.netty.WriteRequestContext
-
- getRequest() - Method in class alluxio.worker.s3.S3NettyHandler
-
get HTTP request.
- getRequestBody() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
optional bytes request_body = 1;
- getRequestBody() - Method in class alluxio.grpc.SubmitJobPRequest
-
optional bytes request_body = 1;
- getRequestBody() - Method in interface alluxio.grpc.SubmitJobPRequestOrBuilder
-
optional bytes request_body = 1;
- getRequestHeader() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- getRequestHeader() - Method in class alluxio.grpc.TransportMessage
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- getRequestHeader() - Method in interface alluxio.grpc.TransportMessageOrBuilder
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- getRequestHeaderBuilder() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- getRequestHeaderOrBuilder() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- getRequestHeaderOrBuilder() - Method in class alluxio.grpc.TransportMessage
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- getRequestHeaderOrBuilder() - Method in interface alluxio.grpc.TransportMessageOrBuilder
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- getRequestId() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
optional int64 requestId = 1;
- getRequestId() - Method in class alluxio.grpc.MessagingRequestHeader
-
optional int64 requestId = 1;
- getRequestId() - Method in interface alluxio.grpc.MessagingRequestHeaderOrBuilder
-
optional int64 requestId = 1;
- getRequestId() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
optional int64 requestId = 1;
- getRequestId() - Method in class alluxio.grpc.MessagingResponseHeader
-
optional int64 requestId = 1;
- getRequestId() - Method in interface alluxio.grpc.MessagingResponseHeaderOrBuilder
-
optional int64 requestId = 1;
- getRequestId() - Method in class alluxio.s3.S3Error
-
- getRequestLatestSnapshotDataMethod() - Static method in class alluxio.grpc.RaftJournalServiceGrpc
-
- getRequestLatestSnapshotInfoMethod() - Static method in class alluxio.grpc.RaftJournalServiceGrpc
-
- getRequestMarshaller() - Method in class alluxio.grpc.DataMessageMarshallerProvider
-
- getRequestRegisterLeaseMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
-
- getRequestType(RequestType) - Method in class alluxio.client.file.dora.netty.NettyDataWriter
-
- getReservedBytes() - Method in interface alluxio.worker.block.meta.StorageDir
-
- getResetPrioritiesMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
-
- getResource() - Method in class alluxio.s3.S3Error
-
- getResource() - Method in exception alluxio.s3.S3Exception
-
- getResourcePoolMetricName(Object) - Static method in class alluxio.metrics.MetricsSystem
-
Get metrics name based on class.
- getResources(String) - Method in class alluxio.extensions.ExtensionsClassLoader
-
- getResponse() - Method in class alluxio.worker.s3.S3NettyHandler
-
get HTTP response.
- getResponseEventFactory() - Static method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
-
Get a response event factory.
- getResponseFuture() - Method in class alluxio.scheduler.job.Task
-
- getResponseHeader() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- getResponseHeader() - Method in class alluxio.grpc.TransportMessage
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- getResponseHeader() - Method in interface alluxio.grpc.TransportMessageOrBuilder
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- getResponseHeaderBuilder() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- getResponseHeaderOrBuilder() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- getResponseHeaderOrBuilder() - Method in class alluxio.grpc.TransportMessage
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- getResponseHeaderOrBuilder() - Method in interface alluxio.grpc.TransportMessageOrBuilder
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- getResponseMarshaller() - Method in class alluxio.grpc.DataMessageMarshallerProvider
-
- getRestS3LocalPort() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getRestS3LocalPort() - Method in interface alluxio.worker.WorkerProcess
-
- getResult() - Method in class alluxio.cli.ValidationResults
-
Get Validation Result.
- getResult() - Method in class alluxio.cli.ValidationTaskResult
-
- getResult() - Method in class alluxio.grpc.JobInfo.Builder
-
optional bytes result = 9;
- getResult() - Method in class alluxio.grpc.JobInfo
-
optional bytes result = 9;
- getResult() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional bytes result = 9;
- getResult() - Method in class alluxio.job.plan.meta.PlanInfo
-
- getResult() - Method in interface alluxio.job.wire.JobInfo
-
- getResult() - Method in class alluxio.job.wire.PlanInfo
-
- getResult() - Method in class alluxio.job.wire.TaskInfo
-
- getResult() - Method in class alluxio.job.wire.WorkflowInfo
-
- getResult() - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
-
Gets the combined result from all batches.
- getRetryable() - Method in class alluxio.grpc.BlockStatus.Builder
-
optional bool retryable = 4;
- getRetryable() - Method in class alluxio.grpc.BlockStatus
-
optional bool retryable = 4;
- getRetryable() - Method in interface alluxio.grpc.BlockStatusOrBuilder
-
optional bool retryable = 4;
- getRetryable() - Method in class alluxio.grpc.FileFailure.Builder
-
optional bool retryable = 4;
- getRetryable() - Method in class alluxio.grpc.FileFailure
-
optional bool retryable = 4;
- getRetryable() - Method in interface alluxio.grpc.FileFailureOrBuilder
-
optional bool retryable = 4;
- getRetryable() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional bool retryable = 4;
- getRetryable() - Method in class alluxio.grpc.LoadFileFailure
-
optional bool retryable = 4;
- getRetryable() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
-
optional bool retryable = 4;
- getRetryable() - Method in class alluxio.grpc.RouteFailure.Builder
-
optional bool retryable = 4;
- getRetryable() - Method in class alluxio.grpc.RouteFailure
-
optional bool retryable = 4;
- getRetryable() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
optional bool retryable = 4;
- getRetryDelay() - Method in class alluxio.proxy.s3.MultipartUploadCleaner
-
Get retry delay.
- getRetryPolicySupplier() - Method in class alluxio.common.RpcPortHealthCheckClient
-
- getReverseResolveMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getRevision() - Method in class alluxio.grpc.BuildVersion.Builder
-
the git revision at the time of building
- getRevision() - Method in class alluxio.grpc.BuildVersion
-
the git revision at the time of building
- getRevision() - Method in interface alluxio.grpc.BuildVersionOrBuilder
-
the git revision at the time of building
- getRevision() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string revision = 5;
- getRevision() - Method in class alluxio.grpc.RegisterMasterPOptions
-
optional string revision = 5;
- getRevision() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
optional string revision = 5;
- getRevision() - Method in class alluxio.master.meta.MasterInfo
-
- getRevision() - Method in class alluxio.master.meta.ProxyInfo
-
- getRevision() - Method in class alluxio.util.webui.NodeInfo
-
Gets worker revision.
- getRevision() - Method in class alluxio.wire.AlluxioMasterInfo
-
Gets revision.
- getRevision() - Method in class alluxio.wire.AlluxioWorkerInfo
-
Gets revision.
- getRevision() - Method in class alluxio.wire.MasterInfo
-
- getRevision() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets revision.
- getRevision() - Method in class alluxio.wire.WorkerInfo
-
- getRevision() - Method in class alluxio.wire.WorkerWebUIOverview
-
Gets revision.
- getRevisionBytes() - Method in class alluxio.grpc.BuildVersion.Builder
-
the git revision at the time of building
- getRevisionBytes() - Method in class alluxio.grpc.BuildVersion
-
the git revision at the time of building
- getRevisionBytes() - Method in interface alluxio.grpc.BuildVersionOrBuilder
-
the git revision at the time of building
- getRevisionBytes() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string revision = 5;
- getRevisionBytes() - Method in class alluxio.grpc.RegisterMasterPOptions
-
optional string revision = 5;
- getRevisionBytes() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
optional string revision = 5;
- getRevisionNumber() - Method in class alluxio.membership.DefaultServiceEntity
-
Get the revision number of currently registered DefaultServiceEntity
on ETCD.
- getRocksStore() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
-
- getRocksStore() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- getRocksStore() - Method in interface alluxio.rocks.RocksCheckpointed
-
- getRole() - Method in class alluxio.cli.LogLevel.TargetInfo
-
- getRoleId() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
Get the role index.
- getRoleServices() - Method in class alluxio.master.backup.BackupLeaderRole
-
- getRoleServices() - Method in interface alluxio.master.backup.BackupRole
-
- getRoleServices() - Method in class alluxio.master.backup.BackupWorkerRole
-
- getRoot() - Method in class alluxio.concurrent.jsr.CountedCompleter
-
Returns the root of the current computation; i.e., this task if it has no completer, else its
completer's root.
- getRoot() - Method in class alluxio.master.file.meta.InodeTree
-
- getRoot() - Method in class alluxio.master.file.meta.InodeTreePersistentState
-
- getRoot() - Method in class alluxio.underfs.AbstractUfsManager
-
- getRoot() - Method in interface alluxio.underfs.UfsManager
-
- getRootCause(Throwable) - Static method in class alluxio.util.CommonUtils
-
Gets the root cause of an exception.
- getRootDir() - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- getRootInodeOwner() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getRootInodeOwner() - Method in interface alluxio.master.file.FileSystemMaster
-
- getRootKey() - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- getRootKey() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- getRootKey() - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- getRootKey() - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Get full path of root in object store.
- getRootKey() - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- getRootKey() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- getRootKey() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getRootPath() - Method in class alluxio.AlluxioURI
-
- getRootPath() - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
- getRoots() - Method in class alluxio.collections.DirectedAcyclicGraph
-
Gets the payloads of all the root nodes of the DAG.
- getRootUFS() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
Gets the UFS Root.
- getRootUfsUri() - Method in class alluxio.fuse.options.FuseCliOptions
-
- getRootUserName() - Method in class alluxio.master.file.meta.InodeTree
-
- getRoute() - Method in class alluxio.grpc.RouteFailure.Builder
-
required .alluxio.grpc.block.Route route = 1;
- getRoute() - Method in class alluxio.grpc.RouteFailure
-
required .alluxio.grpc.block.Route route = 1;
- getRoute() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
required .alluxio.grpc.block.Route route = 1;
- getRouteBuilder() - Method in class alluxio.grpc.RouteFailure.Builder
-
required .alluxio.grpc.block.Route route = 1;
- getRouteOrBuilder() - Method in class alluxio.grpc.RouteFailure.Builder
-
required .alluxio.grpc.block.Route route = 1;
- getRouteOrBuilder() - Method in class alluxio.grpc.RouteFailure
-
required .alluxio.grpc.block.Route route = 1;
- getRouteOrBuilder() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
required .alluxio.grpc.block.Route route = 1;
- getRoutes(int) - Method in class alluxio.grpc.CopyRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutes(int) - Method in class alluxio.grpc.CopyRequest
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutes(int) - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutes(int) - Method in class alluxio.grpc.MoveRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutes(int) - Method in class alluxio.grpc.MoveRequest
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutes(int) - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutes() - Method in class alluxio.master.job.CopyJob.CopyTask
-
- getRoutes() - Method in class alluxio.master.job.MoveJob.MoveTask
-
- getRoutesBuilder(int) - Method in class alluxio.grpc.CopyRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesBuilder(int) - Method in class alluxio.grpc.MoveRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesBuilderList() - Method in class alluxio.grpc.CopyRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesBuilderList() - Method in class alluxio.grpc.MoveRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesCount() - Method in class alluxio.grpc.CopyRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesCount() - Method in class alluxio.grpc.CopyRequest
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesCount() - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesCount() - Method in class alluxio.grpc.MoveRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesCount() - Method in class alluxio.grpc.MoveRequest
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesCount() - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesList() - Method in class alluxio.grpc.CopyRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesList() - Method in class alluxio.grpc.CopyRequest
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesList() - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesList() - Method in class alluxio.grpc.MoveRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesList() - Method in class alluxio.grpc.MoveRequest
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesList() - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilder(int) - Method in class alluxio.grpc.CopyRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilder(int) - Method in class alluxio.grpc.CopyRequest
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilder(int) - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilder(int) - Method in class alluxio.grpc.MoveRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilder(int) - Method in class alluxio.grpc.MoveRequest
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilder(int) - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilderList() - Method in class alluxio.grpc.CopyRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilderList() - Method in class alluxio.grpc.CopyRequest
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilderList() - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilderList() - Method in class alluxio.grpc.MoveRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilderList() - Method in class alluxio.grpc.MoveRequest
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRoutesOrBuilderList() - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
repeated .alluxio.grpc.block.Route routes = 1;
- getRpcAddress() - Method in class alluxio.master.MasterProcess
-
- getRpcAddress() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getRpcAddress() - Method in interface alluxio.master.meta.MetaMaster
-
- getRpcAddress() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getRpcAddress() - Method in class alluxio.wire.AlluxioWorkerInfo
-
- getRpcAddress() - Method in class alluxio.worker.AlluxioJobWorkerProcess
-
- getRpcAddress() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getRpcAddress() - Method in interface alluxio.worker.JobWorkerProcess
-
- getRpcAddress() - Method in interface alluxio.worker.WorkerProcess
-
- getRpcBindAddress() - Method in class alluxio.master.MasterProcess
-
- getRpcInvocationMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets rpc invocation metrics.
- getRpcLocalPort() - Method in class alluxio.master.LocalAlluxioMaster
-
Gets the actual port that the RPC service is listening on.
- getRpcPort() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get rpc port.
- getRpcPort() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int32 rpcPort = 3;
- getRpcPort() - Method in class alluxio.grpc.MasterInfo
-
optional int32 rpcPort = 3;
- getRpcPort() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional int32 rpcPort = 3;
- getRpcPort() - Method in class alluxio.grpc.NetAddress.Builder
-
optional int32 rpcPort = 2;
- getRpcPort() - Method in class alluxio.grpc.NetAddress
-
optional int32 rpcPort = 2;
- getRpcPort() - Method in interface alluxio.grpc.NetAddressOrBuilder
-
optional int32 rpcPort = 2;
- getRpcPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 rpcPort = 2;
- getRpcPort() - Method in class alluxio.grpc.WorkerNetAddress
-
optional int32 rpcPort = 2;
- getRpcPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional int32 rpcPort = 2;
- getRpcPort() - Method in class alluxio.multi.process.MasterNetAddress
-
- getRpcPort() - Method in class alluxio.wire.Address
-
- getRpcPort() - Method in class alluxio.wire.WorkerNetAddress
-
- getRpcPortSocketAddress(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
-
Extracts rpcPort socket address from Alluxio representation of network address.
- getRpcQueueLength() - Method in class alluxio.master.AlluxioExecutorService
-
- getRpcQueueLength() - Method in class alluxio.wire.WorkerWebUIOperations
-
Gets the current RPC queue length.
- getRunAsync() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool runAsync = 2;
- getRunAsync() - Method in class alluxio.grpc.BackupPOptions
-
optional bool runAsync = 2;
- getRunAsync() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
-
optional bool runAsync = 2;
- getRunLimit(long) - Method in class alluxio.heartbeat.CronExpressionIntervalSupplier
-
- getRunLimit(long) - Method in class alluxio.heartbeat.FixedIntervalSupplier
-
- getRunLimit(long) - Method in interface alluxio.heartbeat.SleepIntervalSupplier
-
Gets the run limit from previous ticked.
- getRunMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getRunningThreadCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns an estimate of the number of worker threads that are not blocked waiting to join tasks
or for other managed synchronization.
- getRunTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- getRunTaskCommand() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- getRunTaskCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- getRunTaskCommandBuilder() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- getRunTaskCommandOrBuilder() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- getRunTaskCommandOrBuilder() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- getRunTaskCommandOrBuilder() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- getS3BindAddress() - Method in interface alluxio.worker.DataServer
-
Gets the actual bind socket address for S3.
- getS3BindAddress() - Method in class alluxio.worker.grpc.GrpcDataServer
-
- getS3BindAddress() - Method in class alluxio.worker.netty.NettyDataServer
-
- getS3SyntaxOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- getS3SyntaxOptions() - Method in class alluxio.grpc.RenamePOptions
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- getS3SyntaxOptions() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- getS3SyntaxOptionsBuilder() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- getS3SyntaxOptionsOrBuilder() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- getS3SyntaxOptionsOrBuilder() - Method in class alluxio.grpc.RenamePOptions
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- getS3SyntaxOptionsOrBuilder() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- getS3Task() - Method in class alluxio.proxy.s3.S3Handler
-
get S3Task of this S3Handler.
- getS3Task() - Method in class alluxio.worker.s3.S3NettyHandler
-
get S3Task of this S3Handler.
- getS3WriteType() - Static method in class alluxio.proxy.s3.S3RestUtils
-
- getSafeMode() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional bool safeMode = 4;
- getSafeMode() - Method in class alluxio.grpc.MasterInfo
-
optional bool safeMode = 4;
- getSafeMode() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional bool safeMode = 4;
- getSafeModeManager() - Method in class alluxio.master.AlluxioMasterProcess
-
- getSafeModeManager() - Method in class alluxio.master.CoreMasterContext
-
- getSafeModeManager() - Method in class alluxio.master.MasterProcess
-
- getScale() - Method in class alluxio.grpc.table.Decimal.Builder
-
force using scale first in Decimal.compareTo
- getScale() - Method in class alluxio.grpc.table.Decimal
-
force using scale first in Decimal.compareTo
- getScale() - Method in interface alluxio.grpc.table.DecimalOrBuilder
-
force using scale first in Decimal.compareTo
- getScanCompleted() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanCompleted = 4;
- getScanCompleted() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 scanCompleted = 4;
- getScanCompleted() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 scanCompleted = 4;
- getScanPendingAction() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanPendingAction = 3;
- getScanPendingAction() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 scanPendingAction = 3;
- getScanPendingAction() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 scanPendingAction = 3;
- getScanStartedMs() - Method in class alluxio.grpc.PolicyStatus.Builder
-
scan status
- getScanStartedMs() - Method in class alluxio.grpc.PolicyStatus
-
scan status
- getScanStartedMs() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
scan status
- getScanTotal() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanTotal = 2;
- getScanTotal() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 scanTotal = 2;
- getScanTotal() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 scanTotal = 2;
- getScheduleAsyncPersistenceMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getScheduler() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
Get scheduler.
- getScheduler() - Method in interface alluxio.master.file.FileSystemMaster
-
- getSchedulerInfo(String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
- getSchema() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Schema schema = 5;
- getSchema() - Method in class alluxio.grpc.table.TableInfo
-
optional .alluxio.grpc.table.Schema schema = 5;
- getSchema() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional .alluxio.grpc.table.Schema schema = 5;
- getSchemaBuilder() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Schema schema = 5;
- getSchemaOrBuilder() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Schema schema = 5;
- getSchemaOrBuilder() - Method in class alluxio.grpc.table.TableInfo
-
optional .alluxio.grpc.table.Schema schema = 5;
- getSchemaOrBuilder() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional .alluxio.grpc.table.Schema schema = 5;
- getScheme() - Method in class alluxio.AlluxioURI
-
- getScheme() - Method in class alluxio.hadoop.AbstractFileSystem
-
Gets the URI scheme that maps to the FileSystem
.
- getScheme() - Method in class alluxio.hadoop.FileSystem
-
- getScheme() - Method in class alluxio.hadoop.LocalCacheFileSystem
-
- getScheme(HttpRequest) - Static method in class alluxio.s3.NettyRestUtils
-
Get the scheme of a HttpRequest
.
- getScheme() - Method in class alluxio.uri.MultiPartSchemeURI
-
- getScheme() - Method in class alluxio.uri.StandardURI
-
- getScheme() - Method in interface alluxio.uri.URI
-
- getSchemeAuthority(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
-
- getSchemeComponents(String) - Static method in class alluxio.uri.URI.Factory
-
Returns a
Pair
of components of the given scheme.
- getSchemeSpecificPart() - Method in class alluxio.uri.StandardURI
-
- getSchemeSpecificPart() - Method in interface alluxio.uri.URI
-
- getScope() - Method in class alluxio.client.file.cache.PageInfo
-
- getScope() - Method in class alluxio.conf.PropertyKey
-
- getSecond() - Method in class alluxio.collections.Pair
-
- getSecureRpcPort() - Method in class alluxio.wire.WorkerNetAddress
-
- getSecurityAuthorizationPermissionEnabled() - Method in class alluxio.wire.MasterWebUIInit
-
Gets security authorization permission enabled.
- getSecurityAuthorizationPermissionEnabled() - Method in class alluxio.wire.WorkerWebUIInit
-
Gets security authorization permission enabled.
- getSegmentIndex(int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
-
- getSegmentStartPos(int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
-
- getSelectionPolicy() - Method in class alluxio.resource.DynamicResourcePool.Options
-
- getSelfSignedClientSslContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
-
- getSelfSignedClientSslContext() - Method in interface alluxio.util.network.tls.SslContextProvider
-
- getSelfSignedServerSslContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
-
- getSelfSignedServerSslContext() - Method in interface alluxio.util.network.tls.SslContextProvider
-
- getSequenceNumber(long) - Static method in class alluxio.master.block.BlockId
-
- getSequenceNumber() - Method in class alluxio.master.file.state.DirectoryId
-
- getSequenceNumber() - Method in interface alluxio.master.file.state.DirectoryId.UnmodifiableDirectoryId
-
- getSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
optional int64 sequence_number = 2;
- getSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
optional int64 sequence_number = 2;
- getSequenceNumber() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
-
optional int64 sequence_number = 2;
- getSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
shared fields.
- getSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
shared fields.
- getSequenceNumber() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
shared fields.
- getSerde() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string serde = 1;
- getSerde() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
optional string serde = 1;
- getSerde() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
optional string serde = 1;
- getSerdeBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string serde = 1;
- getSerdeBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
optional string serde = 1;
- getSerdeBytes() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
optional string serde = 1;
- getSerdelibParameters() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
Deprecated.
- getSerdelibParameters() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
Deprecated.
- getSerdelibParameters() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
Deprecated.
- getSerdelibParametersCount() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- getSerdelibParametersCount() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
- getSerdelibParametersCount() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
map<string, string> serdelib_parameters = 4;
- getSerdelibParametersMap() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
map<string, string> serdelib_parameters = 4;
- getSerdelibParametersMap() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
map<string, string> serdelib_parameters = 4;
- getSerdelibParametersMap() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
map<string, string> serdelib_parameters = 4;
- getSerdelibParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
map<string, string> serdelib_parameters = 4;
- getSerdelibParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
map<string, string> serdelib_parameters = 4;
- getSerdelibParametersOrDefault(String, String) - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
map<string, string> serdelib_parameters = 4;
- getSerdelibParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
map<string, string> serdelib_parameters = 4;
- getSerdelibParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
map<string, string> serdelib_parameters = 4;
- getSerdelibParametersOrThrow(String) - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
map<string, string> serdelib_parameters = 4;
- getSerdeParameters() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
Deprecated.
- getSerdeParameters() - Method in class alluxio.grpc.table.layout.hive.Storage
-
Deprecated.
- getSerdeParameters() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
Deprecated.
- getSerdeParametersCount() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- getSerdeParametersCount() - Method in class alluxio.grpc.table.layout.hive.Storage
-
- getSerdeParametersCount() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
map<string, string> serde_parameters = 5;
- getSerdeParametersMap() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
map<string, string> serde_parameters = 5;
- getSerdeParametersMap() - Method in class alluxio.grpc.table.layout.hive.Storage
-
map<string, string> serde_parameters = 5;
- getSerdeParametersMap() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
map<string, string> serde_parameters = 5;
- getSerdeParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
map<string, string> serde_parameters = 5;
- getSerdeParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.Storage
-
map<string, string> serde_parameters = 5;
- getSerdeParametersOrDefault(String, String) - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
map<string, string> serde_parameters = 5;
- getSerdeParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
map<string, string> serde_parameters = 5;
- getSerdeParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.Storage
-
map<string, string> serde_parameters = 5;
- getSerdeParametersOrThrow(String) - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
map<string, string> serde_parameters = 5;
- getSerializedSize() - Method in class alluxio.grpc.ActionInfo
-
- getSerializedSize() - Method in class alluxio.grpc.AddPolicyPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.AddPolicyPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.AddPolicyPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.AddQuorumServerRequest
-
- getSerializedSize() - Method in class alluxio.grpc.AsyncCacheRequest
-
- getSerializedSize() - Method in class alluxio.grpc.AsyncCacheResponse
-
- getSerializedSize() - Method in class alluxio.grpc.BackupPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.BackupPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.BackupPStatus
-
- getSerializedSize() - Method in class alluxio.grpc.BackupStatusPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.Block
-
- getSerializedSize() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.BlockHeartbeatPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.BlockIdList
-
- getSerializedSize() - Method in class alluxio.grpc.BlockInfo
-
- getSerializedSize() - Method in class alluxio.grpc.BlockLocation
-
- getSerializedSize() - Method in class alluxio.grpc.BlockMasterInfo
-
- getSerializedSize() - Method in class alluxio.grpc.BlockStatus
-
- getSerializedSize() - Method in class alluxio.grpc.BlockStoreLocationProto
-
- getSerializedSize() - Method in class alluxio.grpc.BuildVersion
-
- getSerializedSize() - Method in class alluxio.grpc.CacheRequest
-
- getSerializedSize() - Method in class alluxio.grpc.CacheResponse
-
- getSerializedSize() - Method in class alluxio.grpc.CancelPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.CancelPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.CancelPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.CancelTaskCommand
-
- getSerializedSize() - Method in class alluxio.grpc.CheckAccessPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.CheckAccessPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.CheckAccessPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.CheckConsistencyPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.CheckpointPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.CheckpointPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.CheckRequest
-
- getSerializedSize() - Method in class alluxio.grpc.CheckResponse
-
- getSerializedSize() - Method in class alluxio.grpc.Chunk
-
- getSerializedSize() - Method in class alluxio.grpc.ClearMetricsPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ClearMetricsPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.ClearMetricsRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ClearMetricsResponse
-
- getSerializedSize() - Method in class alluxio.grpc.ClientMetrics
-
- getSerializedSize() - Method in class alluxio.grpc.CmdProgress
-
- getSerializedSize() - Method in class alluxio.grpc.CmdStatusBlock
-
- getSerializedSize() - Method in class alluxio.grpc.CmdSummary
-
- getSerializedSize() - Method in class alluxio.grpc.Command
-
- getSerializedSize() - Method in class alluxio.grpc.CommitBlockPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.CommitBlockPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.CommitBlockPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.CompleteFilePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.CompleteFilePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.CompleteFilePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.ConfigCheckReport
-
- getSerializedSize() - Method in class alluxio.grpc.ConfigProperties
-
- getSerializedSize() - Method in class alluxio.grpc.ConfigProperty
-
- getSerializedSize() - Method in class alluxio.grpc.CopyJobPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.CopyRequest
-
- getSerializedSize() - Method in class alluxio.grpc.CopyResponse
-
- getSerializedSize() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.CreateDirectoryPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.CreateFilePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.CreateFilePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.CreateFilePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.DecommissionWorkerPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.DeletePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.DeletePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.DeletePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.DownloadSnapshotPRequest
-
Deprecated.
- getSerializedSize() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
Deprecated.
- getSerializedSize() - Method in class alluxio.grpc.ErrorInfo
-
- getSerializedSize() - Method in class alluxio.grpc.ExistsPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.ExistsPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ExistsPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.File
-
- getSerializedSize() - Method in class alluxio.grpc.FileBlockInfo
-
- getSerializedSize() - Method in class alluxio.grpc.FileFailure
-
- getSerializedSize() - Method in class alluxio.grpc.FileInfo
-
- getSerializedSize() - Method in class alluxio.grpc.FileSystemCommand
-
- getSerializedSize() - Method in class alluxio.grpc.FileSystemCommandOptions
-
- getSerializedSize() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.FreePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.FreePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.FreePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.FreeWorkerRequest
-
- getSerializedSize() - Method in class alluxio.grpc.FreeWorkerResponse
-
- getSerializedSize() - Method in class alluxio.grpc.FsOpPId
-
- getSerializedSize() - Method in class alluxio.grpc.GetActionInfoOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetActionInfoRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetActionInfoResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetBlockInfoPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetBlockInfoPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetBlockInfoPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetCapacityBytesPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetCapacityBytesPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetConfigHashPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetConfigHashPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetConfigReportPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetConfigReportPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetConfigurationPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetConfigurationPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetFileInfoPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetFileInfoPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetFileInfoPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetFilePathPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetFilePathPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobMasterIdPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobMasterIdPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobProgressPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobProgressPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobStatusPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobStatusPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetJobStatusPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetMasterIdPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetMasterIdPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetMasterIdPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetMasterInfoPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetMasterInfoPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetMetricsPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetMetricsPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetMountIdPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetMountIdPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetMountTablePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetMountTablePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetNodeStatePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetNodeStatePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetPolicyStatusPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetPolicyStatusPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetQuorumInfoPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetQuorumInfoPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetRegisterLeasePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetRegisterLeasePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetServiceVersionPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetServiceVersionPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- getSerializedSize() - Method in class alluxio.grpc.GetSnapshotInfoResponse
-
Deprecated.
- getSerializedSize() - Method in class alluxio.grpc.GetSnapshotRequest
-
Deprecated.
- getSerializedSize() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetStatusPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetStatusPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetStatusPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetUfsInfoPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetUfsInfoPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetUfsInfoPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetUsedBytesPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetUsedBytesPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetWorkerIdPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.GetWorkerIdPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.InconsistentProperties
-
- getSerializedSize() - Method in class alluxio.grpc.InconsistentProperty
-
- getSerializedSize() - Method in class alluxio.grpc.InconsistentPropertyValues
-
- getSerializedSize() - Method in class alluxio.grpc.JobCommand
-
- getSerializedSize() - Method in class alluxio.grpc.JobDescription
-
- getSerializedSize() - Method in class alluxio.grpc.JobHeartbeatPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.JobInfo
-
- getSerializedSize() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.JobMasterStatus
-
- getSerializedSize() - Method in class alluxio.grpc.JobProgress
-
- getSerializedSize() - Method in class alluxio.grpc.JobProgressPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.JobServiceSummary
-
- getSerializedSize() - Method in class alluxio.grpc.JobStatusBlock
-
- getSerializedSize() - Method in class alluxio.grpc.JobUnused
-
- getSerializedSize() - Method in class alluxio.grpc.JobWorkerHealth
-
- getSerializedSize() - Method in class alluxio.grpc.JournalQueryRequest
-
- getSerializedSize() - Method in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- getSerializedSize() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ListAllPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.ListAllPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ListAllPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.ListPolicyPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.ListPolicyPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ListPolicyPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.ListProxyStatusPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.ListProxyStatusPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ListProxyStatusPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.ListStatusPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.ListStatusPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ListStatusPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.LoadFileFailure
-
- getSerializedSize() - Method in class alluxio.grpc.LoadFileRequest
-
- getSerializedSize() - Method in class alluxio.grpc.LoadFileResponse
-
- getSerializedSize() - Method in class alluxio.grpc.LoadJobPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.LoadMetadataPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.LoadRequest
-
- getSerializedSize() - Method in class alluxio.grpc.LoadResponse
-
- getSerializedSize() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
- getSerializedSize() - Method in class alluxio.grpc.MasterHeartbeatPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.MasterHeartbeatPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.MasterHeartbeatPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.MasterInfo
-
- getSerializedSize() - Method in class alluxio.grpc.MasterVersion
-
- getSerializedSize() - Method in class alluxio.grpc.MessagingRequestHeader
-
- getSerializedSize() - Method in class alluxio.grpc.MessagingResponseHeader
-
- getSerializedSize() - Method in class alluxio.grpc.Metric
-
- getSerializedSize() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.MetricValue
-
- getSerializedSize() - Method in class alluxio.grpc.MountPointInfo
-
- getSerializedSize() - Method in class alluxio.grpc.MountPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.MountPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.MountPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.MoveBlockRequest
-
- getSerializedSize() - Method in class alluxio.grpc.MoveBlockResponse
-
- getSerializedSize() - Method in class alluxio.grpc.MoveJobPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.MoveRequest
-
- getSerializedSize() - Method in class alluxio.grpc.MoveResponse
-
- getSerializedSize() - Method in class alluxio.grpc.NeedsSyncRequest
-
- getSerializedSize() - Method in class alluxio.grpc.NeedsSyncResponse
-
- getSerializedSize() - Method in class alluxio.grpc.NetAddress
-
- getSerializedSize() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.OpenFilePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.PAcl
-
- getSerializedSize() - Method in class alluxio.grpc.PAclEntry
-
- getSerializedSize() - Method in class alluxio.grpc.PersistCommandOptions
-
- getSerializedSize() - Method in class alluxio.grpc.PersistFile
-
- getSerializedSize() - Method in class alluxio.grpc.PMode
-
- getSerializedSize() - Method in class alluxio.grpc.PolicyInfo
-
- getSerializedSize() - Method in class alluxio.grpc.PolicyStatus
-
- getSerializedSize() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.ProxyStatus
-
- getSerializedSize() - Method in class alluxio.grpc.QuorumServerInfo
-
- getSerializedSize() - Method in class alluxio.grpc.ReadRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ReadResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterCommand
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterJobMasterPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterJobMasterPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterMasterPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterMasterPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterMasterPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.RegisterWorkerPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RemoveBlockRequest
-
- getSerializedSize() - Method in class alluxio.grpc.RemoveBlockResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RemovePolicyPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.RemovePolicyPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.RemovePolicyPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RenamePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.RenamePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.RenamePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.ResetPrioritiesPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.ResetPrioritiesPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ResetPrioritiesPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RetryInfo
-
- getSerializedSize() - Method in class alluxio.grpc.ReverseResolvePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ReverseResolvePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.Route
-
- getSerializedSize() - Method in class alluxio.grpc.RouteFailure
-
- getSerializedSize() - Method in class alluxio.grpc.RunPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.RunPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.RunPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.RunTaskCommand
-
- getSerializedSize() - Method in class alluxio.grpc.S3SyntaxOptions
-
- getSerializedSize() - Method in class alluxio.grpc.SaslMessage
-
- getSerializedSize() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.SetAclPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.SetAclPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.SetAclPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.SetAttributePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.SetAttributePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.SetAttributePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.SetPathConfigurationPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.SetPathConfigurationPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
-
- getSerializedSize() - Method in class alluxio.grpc.SnapshotData
-
- getSerializedSize() - Method in class alluxio.grpc.SnapshotMetadata
-
- getSerializedSize() - Method in class alluxio.grpc.StatusSummary
-
- getSerializedSize() - Method in class alluxio.grpc.StopJobPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.StopJobPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.StorageList
-
- getSerializedSize() - Method in class alluxio.grpc.SubmitJobPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.SubmitJobPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.SubmitOptions
-
- getSerializedSize() - Method in class alluxio.grpc.SubmitRequest
-
- getSerializedSize() - Method in class alluxio.grpc.SubmitResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.AllOrNoneSet
-
- getSerializedSize() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.AttachDatabasePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
- getSerializedSize() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
- getSerializedSize() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
- getSerializedSize() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
- getSerializedSize() - Method in class alluxio.grpc.table.ColumnStatisticsList
-
- getSerializedSize() - Method in class alluxio.grpc.table.Constraint
-
- getSerializedSize() - Method in class alluxio.grpc.table.Database
-
- getSerializedSize() - Method in class alluxio.grpc.table.Date
-
- getSerializedSize() - Method in class alluxio.grpc.table.DateColumnStatsData
-
- getSerializedSize() - Method in class alluxio.grpc.table.Decimal
-
- getSerializedSize() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
- getSerializedSize() - Method in class alluxio.grpc.table.DetachDatabasePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.DetachDatabasePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.Domain
-
- getSerializedSize() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
- getSerializedSize() - Method in class alluxio.grpc.table.EquatableValueSet
-
- getSerializedSize() - Method in class alluxio.grpc.table.FieldSchema
-
- getSerializedSize() - Method in class alluxio.grpc.table.FileStatistics
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetAllTablesPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetAllTablesPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetDatabasePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetDatabasePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetTablePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetTablePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.Layout
-
- getSerializedSize() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
- getSerializedSize() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
- getSerializedSize() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
-
- getSerializedSize() - Method in class alluxio.grpc.table.layout.hive.Storage
-
- getSerializedSize() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
- getSerializedSize() - Method in class alluxio.grpc.table.LayoutSpec
-
- getSerializedSize() - Method in class alluxio.grpc.table.LongColumnStatsData
-
- getSerializedSize() - Method in class alluxio.grpc.table.Partition
-
- getSerializedSize() - Method in class alluxio.grpc.table.PartitionSpec
-
- getSerializedSize() - Method in class alluxio.grpc.table.Range
-
- getSerializedSize() - Method in class alluxio.grpc.table.RangeSet
-
- getSerializedSize() - Method in class alluxio.grpc.table.ReadTablePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.ReadTablePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.Schema
-
- getSerializedSize() - Method in class alluxio.grpc.table.StringColumnStatsData
-
- getSerializedSize() - Method in class alluxio.grpc.table.SyncDatabasePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.SyncDatabasePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.SyncStatus
-
- getSerializedSize() - Method in class alluxio.grpc.table.TableInfo
-
- getSerializedSize() - Method in class alluxio.grpc.table.Transformation
-
- getSerializedSize() - Method in class alluxio.grpc.table.TransformJobInfo
-
- getSerializedSize() - Method in class alluxio.grpc.table.TransformTablePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.table.TransformTablePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.table.Value
-
- getSerializedSize() - Method in class alluxio.grpc.TierList
-
- getSerializedSize() - Method in class alluxio.grpc.TransferLeaderMessage
-
- getSerializedSize() - Method in class alluxio.grpc.TransferLeadershipPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.TransferLeadershipPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.TransportMessage
-
- getSerializedSize() - Method in class alluxio.grpc.TriggerPolicyRequest
-
- getSerializedSize() - Method in class alluxio.grpc.TriggerPolicyResponse
-
- getSerializedSize() - Method in class alluxio.grpc.UfsFileStatus
-
- getSerializedSize() - Method in class alluxio.grpc.UfsInfo
-
- getSerializedSize() - Method in class alluxio.grpc.UfsReadOptions
-
- getSerializedSize() - Method in class alluxio.grpc.UfsStatus
-
- getSerializedSize() - Method in class alluxio.grpc.UnmountPOptions
-
- getSerializedSize() - Method in class alluxio.grpc.UnmountPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.UnmountPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.UpdateMountPRequest
-
- getSerializedSize() - Method in class alluxio.grpc.UpdateMountPResponse
-
- getSerializedSize() - Method in class alluxio.grpc.UpdateUfsModePOptions
-
- getSerializedSize() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
- getSerializedSize() - Method in class alluxio.grpc.UpdateUfsModePResponse
-
- getSerializedSize() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
Deprecated.
- getSerializedSize() - Method in class alluxio.grpc.UploadSnapshotPResponse
-
Deprecated.
- getSerializedSize() - Method in class alluxio.grpc.WorkerIdentity
-
- getSerializedSize() - Method in class alluxio.grpc.WorkerInfo
-
- getSerializedSize() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
- getSerializedSize() - Method in class alluxio.grpc.WorkerNetAddress
-
- getSerializedSize() - Method in class alluxio.grpc.WriteOptions
-
- getSerializedSize() - Method in class alluxio.grpc.WriteRequest
-
- getSerializedSize() - Method in class alluxio.grpc.WriteRequestCommand
-
- getSerializedSize() - Method in class alluxio.grpc.WriteResponse
-
- getSerializedSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
- getSerializedSize() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.Response
-
- getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
- getSerializedSize() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.NewBlockEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.RenameEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.SetAclEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.StringPairEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Job.FileFilter
-
- getSerializedSize() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Journal.JournalOpPId
-
- getSerializedSize() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
- getSerializedSize() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
-
- getSerializedSize() - Method in class alluxio.proto.meta.Block.BlockLocation
-
- getSerializedSize() - Method in class alluxio.proto.meta.Block.BlockMeta
-
- getSerializedSize() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
-
- getSerializedSize() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
- getSerializedSize() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
- getSerializedSize() - Method in class alluxio.proto.shared.Acl.AclActions
-
- getSerializedSize() - Method in class alluxio.proto.shared.Acl.AclEntry
-
- getSerializedSize() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
- getSeries() - Method in class alluxio.job.util.TimeSeries
-
- getServer() - Method in class alluxio.web.WebServer
-
- getServerAddress() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddress() - Method in class alluxio.grpc.AddQuorumServerRequest
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddress() - Method in interface alluxio.grpc.AddQuorumServerRequestOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddress() - Method in class alluxio.grpc.GrpcChannelKey
-
- getServerAddress() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddress() - Method in class alluxio.grpc.QuorumServerInfo
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddress() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddress() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddress() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddressBuilder() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddressBuilder() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddressBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddressBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddressOrBuilder() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddressOrBuilder() - Method in class alluxio.grpc.AddQuorumServerRequest
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddressOrBuilder() - Method in interface alluxio.grpc.AddQuorumServerRequestOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddressOrBuilder() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddressOrBuilder() - Method in class alluxio.grpc.QuorumServerInfo
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddressOrBuilder() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- getServerAddressOrBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddressOrBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddressOrBuilder() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddressOrBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddressOrBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerAddressOrBuilder() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- getServerChannelClass(ChannelType, boolean) - Static method in class alluxio.util.network.NettyUtils
-
Returns the correct ServerSocketChannel
class for use by the
worker.
- getServerChannelClass(boolean, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
-
Returns the correct ServerSocketChannel
class for use by the
worker.
- getServerConnector() - Method in class alluxio.web.WebServer
-
- getServerHostnames(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
-
Gets list of masters/workers in conf directory.
- getServerInfo(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfo(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfo(int) - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoBuilder(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoBuilderList() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoCount() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoCount() - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoCount() - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoList() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoList() - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoList() - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoOrBuilder(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoOrBuilder(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoOrBuilder(int) - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoOrBuilderList() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoOrBuilderList() - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServerInfoOrBuilderList() - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- getServers() - Method in class alluxio.Registry
-
- getServerSSLContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
-
- getServerSSLContext() - Method in interface alluxio.util.network.tls.SslContextProvider
-
- getServerState() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
- getServerState() - Method in class alluxio.grpc.QuorumServerInfo
-
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
- getServerState() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
-
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
- getServiceDefinition() - Method in class alluxio.grpc.GrpcService
-
- getServiceDescriptor() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.FileSystemMasterJobServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.MessagingServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.MetaMasterProxyServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.RaftJournalServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.SaslAuthenticationServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.ServiceVersionClientServiceGrpc
-
- getServiceDescriptor() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getServiceEntityName() - Method in class alluxio.membership.DefaultServiceEntity
-
Get service entity name.
- getServiceName() - Method in class alluxio.AbstractClient
-
- getServiceName() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getServiceName() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- getServiceName() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- getServiceName() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
-
- getServiceName() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
-
- getServiceName() - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
-
- getServiceName() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
-
- getServiceName() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getServiceName() - Method in class alluxio.master.file.FileSystemMasterClient
-
- getServiceName() - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
-
- getServiceName() - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
-
- getServiceName() - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
-
- getServiceName() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
-
- getServiceName() - Method in class alluxio.proxy.RetryHandlingMetaMasterProxyClient
-
- getServiceName() - Method in class alluxio.security.CurrentUser
-
- getServiceName() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
-
Gets service name.
- getServiceName() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
-
Gets service name.
- getServiceName() - Method in class alluxio.worker.block.BlockMasterClient
-
- getServiceName() - Method in class alluxio.worker.file.FileSystemMasterClient
-
- getServiceName() - Method in class alluxio.worker.job.RetryHandlingJobMasterClient
-
- getServices() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getServices() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getServices() - Method in class alluxio.master.job.JobMaster
-
- getServices() - Method in class alluxio.master.journal.DefaultJournalMaster
-
- getServices() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getServices() - Method in class alluxio.master.metrics.DefaultMetricsMaster
-
- getServices() - Method in class alluxio.master.NoopMaster
-
- getServices() - Method in interface alluxio.Server
-
- getServices() - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getServices() - Method in class alluxio.worker.JobWorker
-
- getServiceType() - Method in class alluxio.common.RpcPortHealthCheckClient
-
- getServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
The purpose of this field is to make grpc service on standby masters work without
making client changes and keeps backwards compatibility.
- getServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest
-
The purpose of this field is to make grpc service on standby masters work without
making client changes and keeps backwards compatibility.
- getServiceType() - Method in interface alluxio.grpc.GetServiceVersionPRequestOrBuilder
-
The purpose of this field is to make grpc service on standby masters work without
making client changes and keeps backwards compatibility.
- getServiceVersion() - Method in class alluxio.AbstractClient
-
- getServiceVersion() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getServiceVersion() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- getServiceVersion() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- getServiceVersion() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
-
- getServiceVersion() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
-
- getServiceVersion() - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
-
- getServiceVersion() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
-
- getServiceVersion() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getServiceVersion(GetServiceVersionPRequest, StreamObserver<GetServiceVersionPResponse>) - Method in interface alluxio.grpc.ServiceVersionClientServiceGrpc.AsyncService
-
Returns the version of the master service.
- getServiceVersion(GetServiceVersionPRequest) - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceBlockingStub
-
Returns the version of the master service.
- getServiceVersion(GetServiceVersionPRequest) - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceFutureStub
-
Returns the version of the master service.
- getServiceVersion(GetServiceVersionPRequest, StreamObserver<GetServiceVersionPResponse>) - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceStub
-
Returns the version of the master service.
- getServiceVersion(GetServiceVersionPRequest, StreamObserver<GetServiceVersionPResponse>) - Method in class alluxio.grpc.ServiceVersionClientServiceHandler
-
- getServiceVersion() - Method in class alluxio.master.file.FileSystemMasterClient
-
- getServiceVersion() - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
-
- getServiceVersion() - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
-
- getServiceVersion() - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
-
- getServiceVersion() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
-
- getServiceVersion() - Method in class alluxio.proxy.RetryHandlingMetaMasterProxyClient
-
- getServiceVersion() - Method in class alluxio.worker.block.BlockMasterClient
-
- getServiceVersion() - Method in class alluxio.worker.file.FileSystemMasterClient
-
- getServiceVersion() - Method in class alluxio.worker.job.RetryHandlingJobMasterClient
-
- GetServiceVersionPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.version.GetServiceVersionPRequest
- GetServiceVersionPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.version.GetServiceVersionPRequest
- GetServiceVersionPRequestOrBuilder - Interface in alluxio.grpc
-
- GetServiceVersionPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.version.GetServiceVersionPResponse
- GetServiceVersionPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.version.GetServiceVersionPResponse
- GetServiceVersionPResponseOrBuilder - Interface in alluxio.grpc
-
- getServletContext() - Method in class alluxio.proxy.s3.S3Handler
-
get ServletContext from current http conversation.
- getServletRequest() - Method in class alluxio.proxy.s3.S3Handler
-
get HttpServletRequest of this request.
- getServletResponse() - Method in class alluxio.proxy.s3.S3Handler
-
get HttpServletResponse of this request.
- getSessionId() - Method in class alluxio.SessionInfo
-
- getSessionId() - Method in class alluxio.wire.BlockReadRequest
-
- getSessionId() - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- getSessionId() - Method in class alluxio.worker.grpc.WriteRequest
-
- getSessionId() - Method in class alluxio.worker.netty.ReadRequest
-
- getSessionTempBlocks(long) - Method in interface alluxio.worker.block.meta.StorageDir
-
Gets the temporary blocks associated with a session in this
StorageDir
, an empty list
is returned if the session has no temporary blocks in this
StorageDir
.
- getSetAcl() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- getSetAcl() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- getSetAcl() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- getSetAclBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- getSetAclMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getSetAclOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- getSetAclOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- getSetAclOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- getSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- getSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- getSetAttribute() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- getSetAttributeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- getSetAttributeMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getSetAttributeMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getSetAttributeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- getSetAttributeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- getSetAttributeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- getSetBlocks(int) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
Overwrite the blocks list
- getSetBlocks(int) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
Overwrite the blocks list
- getSetBlocks(int) - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
Overwrite the blocks list
- getSetBlocksCount() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
Overwrite the blocks list
- getSetBlocksCount() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
Overwrite the blocks list
- getSetBlocksCount() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
Overwrite the blocks list
- getSetBlocksList() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
Overwrite the blocks list
- getSetBlocksList() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
Overwrite the blocks list
- getSetBlocksList() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
Overwrite the blocks list
- getSetPathConfigurationMethod() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
-
- getSetPermissionCommand(String, String) - Static method in class alluxio.util.ShellUtils
-
Returns a Unix command to set permission.
- getSetTaskPoolSizeCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- getSetTaskPoolSizeCommand() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- getSetTaskPoolSizeCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- getSetTaskPoolSizeCommandBuilder() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- getSetTaskPoolSizeCommandOrBuilder() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- getSetTaskPoolSizeCommandOrBuilder() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- getSetTaskPoolSizeCommandOrBuilder() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- getShadowCacheByteHit() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- getShadowCacheByteHit() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- getShadowCacheByteHit() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- getShadowCacheByteHit() - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
- getShadowCacheByteRead() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- getShadowCacheByteRead() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- getShadowCacheByteRead() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- getShadowCacheByteRead() - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
- getShadowCacheBytes() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- getShadowCacheBytes() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- getShadowCacheBytes(CacheScope) - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- getShadowCacheBytes() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- getShadowCacheBytes(CacheScope) - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- getShadowCacheBytes() - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
- getShadowCacheBytes(CacheScope) - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
- getShadowCachePageHit() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- getShadowCachePageHit() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- getShadowCachePageHit() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- getShadowCachePageHit() - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
- getShadowCachePageRead() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- getShadowCachePageRead() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- getShadowCachePageRead() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- getShadowCachePageRead() - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
- getShadowCachePages() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- getShadowCachePages() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- getShadowCachePages(CacheScope) - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- getShadowCachePages() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- getShadowCachePages(CacheScope) - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- getShadowCachePages() - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
- getShadowCachePages(CacheScope) - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
- getShared() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional bool shared = 7;
- getShared() - Method in class alluxio.grpc.MountPointInfo
-
optional bool shared = 7;
- getShared() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional bool shared = 7;
- getShared() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional bool shared = 3;
- getShared() - Method in class alluxio.grpc.MountPOptions
-
optional bool shared = 3;
- getShared() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
optional bool shared = 3;
- getShared() - Method in class alluxio.master.file.meta.MountTable.Resolution
-
- getShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional bool shared = 5;
- getShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional bool shared = 5;
- getShared() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional bool shared = 5;
- getShared() - Method in class alluxio.wire.MountPointInfo
-
- getSharedLibraryFileName(String) - Static method in class alluxio.jnifuse.utils.Environment
-
- getSharedLibraryName(String) - Static method in class alluxio.jnifuse.utils.Environment
-
- getSharedLockCount() - Method in class alluxio.rocks.RocksStore
-
Gets the number of shared lock on the RocksStore.
- getSharedWaitersAndHolders() - Method in class alluxio.master.StateLockManager
-
- getShellName() - Method in class alluxio.cli.AbstractShell
-
- getShellName() - Method in class alluxio.cli.bundler.CollectInfo
-
- getShellName() - Method in class alluxio.cli.extensions.ExtensionsShell
-
- getShellName() - Method in class alluxio.cli.fs.FileSystemShell
-
- getShellName() - Method in class alluxio.cli.fsadmin.FileSystemAdminShell
-
- getShouldPersistTime() - Method in class alluxio.master.file.meta.InodeFile
-
- getShouldPersistTime() - Method in interface alluxio.master.file.meta.InodeFileView
-
- getShouldPersistTime() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getShouldPersistTime() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 should_persist_time = 27;
- getShouldPersistTime() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 should_persist_time = 27;
- getShouldPersistTime() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 should_persist_time = 27;
- getShouldPersistTime() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 should_persist_time = 28;
- getShouldPersistTime() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 should_persist_time = 28;
- getShouldPersistTime() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 should_persist_time = 28;
- getShowPermissions() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets show permissions.
- getShowPermissions() - Method in class alluxio.wire.MasterWebUIData
-
Gets show permissions.
- getSignature() - Method in class alluxio.s3.auth.AwsAuthInfo
-
- getSignature() - Method in class alluxio.s3.signature.SignatureInfo
-
- getSignedHeaders() - Method in class alluxio.s3.signature.SignatureInfo
-
- getSize() - Method in class alluxio.cli.fs.command.job.JobAttempt
-
Get how many files contained in job attempt.
- getSize() - Method in class alluxio.proxy.s3.ListPartsResult.Part
-
- getSize() - Method in class alluxio.s3.ListBucketResult.Content
-
- getSize() - Method in class alluxio.util.UnixMountInfo.Options
-
- getSize() - Method in class alluxio.util.webui.UIFileInfo
-
Gets size.
- getSize() - Method in class alluxio.worker.block.AllocateOptions
-
- getSizeFromBytes(long) - Static method in class alluxio.util.FormatUtils
-
Returns a human-readable version of bytes 10GB 2048KB etc.
- getSizeInBytes() - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
-
- getSizeInBytes() - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
-
- getSizeInTags() - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
-
- getSizeInTags() - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
-
- getSkewed() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional bool skewed = 4;
- getSkewed() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional bool skewed = 4;
- getSkewed() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional bool skewed = 4;
- getSkipIfExists() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
optional bool skip_if_exists = 4;
- getSkipIfExists() - Method in class alluxio.grpc.LoadFileRequest
-
optional bool skip_if_exists = 4;
- getSkipIfExists() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
optional bool skip_if_exists = 4;
- getSkipIfExists() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool skipIfExists = 5;
- getSkipIfExists() - Method in class alluxio.grpc.LoadJobPOptions
-
optional bool skipIfExists = 5;
- getSkipIfExists() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
-
optional bool skipIfExists = 5;
- getSkipIfExists() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional bool skip_if_exists = 10;
- getSkipIfExists() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional bool skip_if_exists = 10;
- getSkipIfExists() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional bool skip_if_exists = 10;
- getSleeper() - Method in class alluxio.time.TimeContext
-
- getSleepTime() - Method in class alluxio.retry.ExponentialBackoffRetry
-
- getSleepTime() - Method in class alluxio.retry.SleepingRetry
-
How long to sleep before the next retry is performed.
- getSleepUnit() - Method in class alluxio.retry.SleepingRetry
-
- getSlotIndex() - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
-
- getSnapshot(UfsJournal) - Static method in class alluxio.master.journal.ufs.UfsJournalSnapshot
-
Creates a snapshot of the journal.
- getSnapshot() - Method in class alluxio.metrics.MaxReservoir
-
Returns a snapshot of the reservoir's values, which has the max value
set as the overall max value sent as an update to this reservoir.
- getSnapshotDir() - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
-
- getSnapshotIndex() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional int64 snapshotIndex = 2;
- getSnapshotIndex() - Method in class alluxio.grpc.SnapshotData
-
optional int64 snapshotIndex = 2;
- getSnapshotIndex() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
optional int64 snapshotIndex = 2;
- getSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional int64 snapshotIndex = 2;
- getSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata
-
optional int64 snapshotIndex = 2;
- getSnapshotIndex() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
-
optional int64 snapshotIndex = 2;
- getSnapshotInfo() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- getSnapshotInfo() - Method in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- getSnapshotInfo() - Method in interface alluxio.grpc.GetSnapshotInfoRequestOrBuilder
-
Deprecated.
- getSnapshotInfoBuilder() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- getSnapshotInfoOrBuilder() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- getSnapshotInfoOrBuilder() - Method in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- getSnapshotInfoOrBuilder() - Method in interface alluxio.grpc.GetSnapshotInfoRequestOrBuilder
-
Deprecated.
- GetSnapshotInfoRequest - Class in alluxio.grpc
-
Deprecated.
- getSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- getSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest
-
Deprecated.
- getSnapshotInfoRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
Deprecated.
- GetSnapshotInfoRequest.Builder - Class in alluxio.grpc
-
Deprecated.
Protobuf type alluxio.grpc.meta.GetSnapshotInfoRequest
- getSnapshotInfoRequestBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- GetSnapshotInfoRequestOrBuilder - Interface in alluxio.grpc
-
Deprecated.
- getSnapshotInfoRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- getSnapshotInfoRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest
-
Deprecated.
- getSnapshotInfoRequestOrBuilder() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
Deprecated.
- GetSnapshotInfoResponse - Class in alluxio.grpc
-
Deprecated.
- getSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- getSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- getSnapshotInfoResponse() - Method in interface alluxio.grpc.JournalQueryResponseOrBuilder
-
Deprecated.
- GetSnapshotInfoResponse.Builder - Class in alluxio.grpc
-
Deprecated.
Protobuf type alluxio.grpc.meta.GetSnapshotInfoResponse
- getSnapshotInfoResponseBuilder() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- GetSnapshotInfoResponseOrBuilder - Interface in alluxio.grpc
-
Deprecated.
- getSnapshotInfoResponseOrBuilder() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- getSnapshotInfoResponseOrBuilder() - Method in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- getSnapshotInfoResponseOrBuilder() - Method in interface alluxio.grpc.JournalQueryResponseOrBuilder
-
Deprecated.
- GetSnapshotRequest - Class in alluxio.grpc
-
Deprecated.
- getSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- getSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest
-
Deprecated.
- getSnapshotRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
Deprecated.
- GetSnapshotRequest.Builder - Class in alluxio.grpc
-
Deprecated.
Protobuf type alluxio.grpc.meta.GetSnapshotRequest
- getSnapshotRequestBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- GetSnapshotRequestOrBuilder - Interface in alluxio.grpc
-
Deprecated.
- getSnapshotRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- getSnapshotRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest
-
Deprecated.
- getSnapshotRequestOrBuilder() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
Deprecated.
- getSnapshotTerm() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional int64 snapshotTerm = 1;
- getSnapshotTerm() - Method in class alluxio.grpc.SnapshotData
-
optional int64 snapshotTerm = 1;
- getSnapshotTerm() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
optional int64 snapshotTerm = 1;
- getSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional int64 snapshotTerm = 1;
- getSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata
-
optional int64 snapshotTerm = 1;
- getSnapshotTerm() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
-
optional int64 snapshotTerm = 1;
- getSocketAddress() - Method in class alluxio.grpc.GrpcServerAddress
-
- getSortedBy(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedBy(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedBy(int) - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByBuilder(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByBuilderList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByCount() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByList() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByOrBuilder(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByOrBuilder(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByOrBuilder(int) - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByOrBuilderList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByOrBuilderList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSortedByOrBuilderList() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- getSource(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
- getSource(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
-
- getSource(PropertyKey) - Static method in class alluxio.conf.Configuration
-
- getSource(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getSource() - Method in class alluxio.grpc.ClientMetrics.Builder
-
optional string source = 1;
- getSource() - Method in class alluxio.grpc.ClientMetrics
-
optional string source = 1;
- getSource() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
-
optional string source = 1;
- getSource() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string source = 2;
- getSource() - Method in class alluxio.grpc.ConfigProperty
-
optional string source = 2;
- getSource() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
-
optional string source = 2;
- getSource() - Method in class alluxio.grpc.Metric.Builder
-
optional string source = 2;
- getSource() - Method in class alluxio.grpc.Metric
-
optional string source = 2;
- getSource() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional string source = 2;
- getSource() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
-
- getSource() - Method in class alluxio.job.plan.migrate.MigrateCommand
-
- getSource() - Method in class alluxio.job.plan.migrate.MigrateConfig
-
- getSource() - Method in class alluxio.master.meta.checkconf.ConfigRecord
-
- getSource() - Method in class alluxio.metrics.Metric
-
- getSource(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getSource() - Method in class alluxio.wire.Property
-
- getSourceBytes() - Method in class alluxio.grpc.ClientMetrics.Builder
-
optional string source = 1;
- getSourceBytes() - Method in class alluxio.grpc.ClientMetrics
-
optional string source = 1;
- getSourceBytes() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
-
optional string source = 1;
- getSourceBytes() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string source = 2;
- getSourceBytes() - Method in class alluxio.grpc.ConfigProperty
-
optional string source = 2;
- getSourceBytes() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
-
optional string source = 2;
- getSourceBytes() - Method in class alluxio.grpc.Metric.Builder
-
optional string source = 2;
- getSourceBytes() - Method in class alluxio.grpc.Metric
-
optional string source = 2;
- getSourceBytes() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional string source = 2;
- getSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHost() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHost() - Method in class alluxio.grpc.CacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHost() - Method in class alluxio.grpc.CacheRequest
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHost() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHost() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHostBytes() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHostBytes() - Method in class alluxio.grpc.AsyncCacheRequest
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHostBytes() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHostBytes() - Method in class alluxio.grpc.CacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHostBytes() - Method in class alluxio.grpc.CacheRequest
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHostBytes() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHostBytes() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHostBytes() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourceHostBytes() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- getSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int32 source_port = 3;
- getSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest
-
optional int32 source_port = 3;
- getSourcePort() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
optional int32 source_port = 3;
- getSourcePort() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int32 source_port = 3;
- getSourcePort() - Method in class alluxio.grpc.CacheRequest
-
optional int32 source_port = 3;
- getSourcePort() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional int32 source_port = 3;
- getSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int32 source_port = 3;
- getSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
optional int32 source_port = 3;
- getSourcePort() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
optional int32 source_port = 3;
- getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- getSpace(String, UnderFileSystem.SpaceType) - Method in interface alluxio.underfs.UnderFileSystem
-
Queries the under file system about the space of the indicated path (e.g., space left, space
used and etc).
- getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional int64 space_to_reserve = 10;
- getSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand
-
optional int64 space_to_reserve = 10;
- getSpaceToReserve() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional int64 space_to_reserve = 10;
- getSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int64 space_to_reserve = 4;
- getSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
optional int64 space_to_reserve = 4;
- getSpaceToReserve() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
-
optional int64 space_to_reserve = 4;
- getSpec() - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
optional string spec = 1;
- getSpec() - Method in class alluxio.grpc.table.LayoutSpec
-
optional string spec = 1;
- getSpec() - Method in interface alluxio.grpc.table.LayoutSpecOrBuilder
-
optional string spec = 1;
- getSpec() - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
optional string spec = 1;
- getSpec() - Method in class alluxio.grpc.table.PartitionSpec
-
optional string spec = 1;
- getSpec() - Method in interface alluxio.grpc.table.PartitionSpecOrBuilder
-
optional string spec = 1;
- getSpecBytes() - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
optional string spec = 1;
- getSpecBytes() - Method in class alluxio.grpc.table.LayoutSpec
-
optional string spec = 1;
- getSpecBytes() - Method in interface alluxio.grpc.table.LayoutSpecOrBuilder
-
optional string spec = 1;
- getSpecBytes() - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
optional string spec = 1;
- getSpecBytes() - Method in class alluxio.grpc.table.PartitionSpec
-
optional string spec = 1;
- getSpecBytes() - Method in interface alluxio.grpc.table.PartitionSpecOrBuilder
-
optional string spec = 1;
- getSrc() - Method in class alluxio.grpc.Route.Builder
-
required string src = 1;
- getSrc() - Method in class alluxio.grpc.Route
-
required string src = 1;
- getSrc() - Method in interface alluxio.grpc.RouteOrBuilder
-
required string src = 1;
- getSrc() - Method in class alluxio.job.CopyJobRequest
-
- getSrc() - Method in class alluxio.job.MoveJobRequest
-
- getSrc() - Method in class alluxio.master.job.CopyJob
-
- getSrc() - Method in class alluxio.master.job.MoveJob
-
- getSrc() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string src = 1;
- getSrc() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required string src = 1;
- getSrc() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required string src = 1;
- getSrc() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string src = 1;
- getSrc() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required string src = 1;
- getSrc() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required string src = 1;
- getSrcBytes() - Method in class alluxio.grpc.Route.Builder
-
required string src = 1;
- getSrcBytes() - Method in class alluxio.grpc.Route
-
required string src = 1;
- getSrcBytes() - Method in interface alluxio.grpc.RouteOrBuilder
-
required string src = 1;
- getSrcBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string src = 1;
- getSrcBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required string src = 1;
- getSrcBytes() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required string src = 1;
- getSrcBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string src = 1;
- getSrcBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required string src = 1;
- getSrcBytes() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required string src = 1;
- getSrcPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string srcPath = 2;
- getSrcPath() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string srcPath = 2;
- getSrcPath() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string srcPath = 2;
- getSrcPathBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string srcPath = 2;
- getSrcPathBytes() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string srcPath = 2;
- getSrcPathBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string srcPath = 2;
- getStandbyMasterInfos() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getStandbyMasterInfos() - Method in interface alluxio.master.meta.MetaMaster
-
- getStandbyMasterInfos() - Method in class alluxio.wire.MasterWebUIMasters
-
Get info of standby masters.
- getStandbyServices() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getStandbyServices() - Method in interface alluxio.master.Master
-
- getStandbyServices() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getStart() - Method in class alluxio.wire.BlockReadRequest
-
- getStart() - Method in class alluxio.worker.netty.ReadRequest
-
- getStartAfter() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Start the listing after this path.
- getStartAfter() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Start the listing after this path.
- getStartAfter() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Start the listing after this path.
- getStartAfter() - Method in class alluxio.s3.ListBucketOptions
-
- getStartAfter() - Method in class alluxio.s3.ListBucketResult
-
- getStartAfterBytes() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Start the listing after this path.
- getStartAfterBytes() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Start the listing after this path.
- getStartAfterBytes() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Start the listing after this path.
- getStartDelayMs() - Method in class alluxio.stress.job.StressBenchConfig
-
- getStartFrom() - Method in class alluxio.master.metastore.ReadOption
-
- getStartMs() - Method in class alluxio.master.predicate.interval.Interval
-
- getStartTime() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get started time.
- getStartTime() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional int64 startTime = 3;
- getStartTime() - Method in class alluxio.grpc.JobMasterStatus
-
optional int64 startTime = 3;
- getStartTime() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional int64 startTime = 3;
- getStartTime() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional int64 startTime = 2;
- getStartTime() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
optional int64 startTime = 2;
- getStartTime() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
-
optional int64 startTime = 2;
- getStartTime() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional int64 startTime = 3;
- getStartTime() - Method in class alluxio.grpc.ProxyStatus
-
optional int64 startTime = 3;
- getStartTime() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional int64 startTime = 3;
- getStartTime() - Method in class alluxio.job.MasterWorkerInfo
-
- getStartTime() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
No locking required.
- getStartTime() - Method in class alluxio.util.webui.UIWorkerInfo
-
Gets start time.
- getStartTime() - Method in class alluxio.wire.MasterInfo
-
- getStartTime() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets start time.
- getStartTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int64 startTimeMs = 5;
- getStartTimeMs() - Method in class alluxio.grpc.MasterInfo
-
optional int64 startTimeMs = 5;
- getStartTimeMs() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional int64 startTimeMs = 5;
- getStartTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional int64 startTimeMs = 2;
- getStartTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
optional int64 startTimeMs = 2;
- getStartTimeMs() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
-
optional int64 startTimeMs = 2;
- getStartTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional int64 startTimeMs = 2;
- getStartTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions
-
optional int64 startTimeMs = 2;
- getStartTimeMs() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
optional int64 startTimeMs = 2;
- getStartTimeMs() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 startTimeMs = 7;
- getStartTimeMs() - Method in class alluxio.grpc.WorkerInfo
-
optional int64 startTimeMs = 7;
- getStartTimeMs() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional int64 startTimeMs = 7;
- getStartTimeMs() - Method in class alluxio.master.CoreMasterContext
-
- getStartTimeMs() - Method in class alluxio.master.MasterProcess
-
- getStartTimeMs() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getStartTimeMs() - Method in class alluxio.master.meta.JobMasterInfo
-
- getStartTimeMs() - Method in class alluxio.master.meta.MasterInfo
-
- getStartTimeMs() - Method in interface alluxio.master.meta.MetaMaster
-
- getStartTimeMs() - Method in class alluxio.master.meta.ProxyInfo
-
- getStartTimeMs() - Method in class alluxio.proxy.AlluxioProxyProcess
-
- getStartTimeMs() - Method in interface alluxio.proxy.ProxyProcess
-
- getStartTimeMs() - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- getStartTimeMs() - Method in class alluxio.wire.AlluxioJobWorkerInfo
-
- getStartTimeMs() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getStartTimeMs() - Method in class alluxio.wire.AlluxioProxyInfo
-
- getStartTimeMs() - Method in class alluxio.wire.AlluxioWorkerInfo
-
- getStartTimeMs() - Method in class alluxio.wire.WorkerInfo
-
- getStartTimeMs() - Method in class alluxio.worker.AlluxioJobWorkerProcess
-
- getStartTimeMs() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getStartTimeMs() - Method in interface alluxio.worker.JobWorkerProcess
-
- getStartTimeMs() - Method in interface alluxio.worker.WorkerProcess
-
- getState() - Method in class alluxio.cli.ValidationTaskResult
-
- getState() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional string state = 1;
- getState() - Method in class alluxio.grpc.JobMasterStatus
-
optional string state = 1;
- getState() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional string state = 1;
- getState() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string state = 3;
- getState() - Method in class alluxio.grpc.MasterVersion
-
optional string state = 3;
- getState() - Method in interface alluxio.grpc.MasterVersionOrBuilder
-
optional string state = 3;
- getState() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional string state = 2;
- getState() - Method in class alluxio.grpc.ProxyStatus
-
optional string state = 2;
- getState() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional string state = 2;
- getState() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional string state = 4;
- getState() - Method in class alluxio.grpc.WorkerInfo
-
optional string state = 4;
- getState() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional string state = 4;
- getState() - Method in class alluxio.master.AbstractPrimarySelector
-
- getState() - Method in class alluxio.master.AlwaysStandbyPrimarySelector
-
- getState() - Method in interface alluxio.master.PrimarySelector
-
- getState() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 3;
- getState() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required .alluxio.proto.journal.PJobState state = 3;
- getState() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required .alluxio.proto.journal.PJobState state = 3;
- getState() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 2;
- getState() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required .alluxio.proto.journal.PJobState state = 2;
- getState() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required .alluxio.proto.journal.PJobState state = 2;
- getState() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 3;
- getState() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required .alluxio.proto.journal.PJobState state = 3;
- getState() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required .alluxio.proto.journal.PJobState state = 3;
- getState() - Method in class alluxio.util.webui.NodeInfo
-
Gets state.
- getState() - Method in class alluxio.wire.BackupStatus
-
- getState() - Method in class alluxio.wire.WorkerInfo
-
- getStateBytes() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional string state = 1;
- getStateBytes() - Method in class alluxio.grpc.JobMasterStatus
-
optional string state = 1;
- getStateBytes() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional string state = 1;
- getStateBytes() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string state = 3;
- getStateBytes() - Method in class alluxio.grpc.MasterVersion
-
optional string state = 3;
- getStateBytes() - Method in interface alluxio.grpc.MasterVersionOrBuilder
-
optional string state = 3;
- getStateBytes() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional string state = 2;
- getStateBytes() - Method in class alluxio.grpc.ProxyStatus
-
optional string state = 2;
- getStateBytes() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional string state = 2;
- getStateBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional string state = 4;
- getStateBytes() - Method in class alluxio.grpc.WorkerInfo
-
optional string state = 4;
- getStateBytes() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional string state = 4;
- getStateLockHolders() - Method in interface alluxio.client.file.FileSystemMasterClient
-
- getStateLockHolders() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- getStateLockHolders(GetStateLockHoldersPRequest, StreamObserver<GetStateLockHoldersPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
- getStateLockHolders(GetStateLockHoldersPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
- getStateLockHolders(GetStateLockHoldersPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
- getStateLockHolders(GetStateLockHoldersPRequest, StreamObserver<GetStateLockHoldersPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
- getStateLockHolders(GetStateLockHoldersPRequest, StreamObserver<GetStateLockHoldersPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- GetStateLockHoldersPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStateLockHoldersPOptions
- GetStateLockHoldersPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStateLockHoldersPOptions
- GetStateLockHoldersPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetStateLockHoldersPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStateLockHoldersPRequest
- GetStateLockHoldersPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStateLockHoldersPRequest
- GetStateLockHoldersPRequestOrBuilder - Interface in alluxio.grpc
-
- GetStateLockHoldersPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStateLockHoldersPResponse
- GetStateLockHoldersPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStateLockHoldersPResponse
- GetStateLockHoldersPResponseOrBuilder - Interface in alluxio.grpc
-
- getStateLockManager() - Method in class alluxio.master.MasterContext
-
- getStateLockSharedWaitersAndHolders() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getStateLockSharedWaitersAndHolders() - Method in interface alluxio.master.file.FileSystemMaster
-
- getStateMachine() - Method in class alluxio.master.journal.raft.RaftJournal
-
- getStateMachineStorage() - Method in class alluxio.master.journal.raft.JournalStateMachine
-
- getStateUnsafe() - Method in class alluxio.master.AbstractPrimarySelector
-
- getStateUnsafe() - Method in class alluxio.master.AlwaysStandbyPrimarySelector
-
- getStateUnsafe() - Method in interface alluxio.master.PrimarySelector
-
- getStatistics(int) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatistics(int) - Method in class alluxio.grpc.table.ColumnStatisticsList
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatistics(int) - Method in interface alluxio.grpc.table.ColumnStatisticsListOrBuilder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatistics(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatistics(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatistics(int) - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPResponseOrBuilder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsBuilder(int) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsBuilder(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsBuilderList() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsBuilderList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsCount() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsCount() - Method in class alluxio.grpc.table.ColumnStatisticsList
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsCount() - Method in interface alluxio.grpc.table.ColumnStatisticsListOrBuilder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsCount() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsCount() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsCount() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPResponseOrBuilder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsList() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsList() - Method in class alluxio.grpc.table.ColumnStatisticsList
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsList() - Method in interface alluxio.grpc.table.ColumnStatisticsListOrBuilder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsList() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPResponseOrBuilder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilder(int) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilder(int) - Method in class alluxio.grpc.table.ColumnStatisticsList
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilder(int) - Method in interface alluxio.grpc.table.ColumnStatisticsListOrBuilder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilder(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilder(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilder(int) - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPResponseOrBuilder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilderList() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilderList() - Method in class alluxio.grpc.table.ColumnStatisticsList
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilderList() - Method in interface alluxio.grpc.table.ColumnStatisticsListOrBuilder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilderList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilderList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStatisticsOrBuilderList() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPResponseOrBuilder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- getStats() - Method in class alluxio.grpc.table.Layout.Builder
-
Deprecated.
- getStats() - Method in class alluxio.grpc.table.Layout
-
Deprecated.
- getStats() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
Deprecated.
- getStatsCount() - Method in class alluxio.grpc.table.Layout.Builder
-
- getStatsCount() - Method in class alluxio.grpc.table.Layout
-
- getStatsCount() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- getStatsMap() - Method in class alluxio.grpc.table.Layout.Builder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- getStatsMap() - Method in class alluxio.grpc.table.Layout
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- getStatsMap() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- getStatsOrDefault(String, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.Layout.Builder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- getStatsOrDefault(String, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.Layout
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- getStatsOrDefault(String, ColumnStatisticsInfo) - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- getStatsOrThrow(String) - Method in class alluxio.grpc.table.Layout.Builder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- getStatsOrThrow(String) - Method in class alluxio.grpc.table.Layout
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- getStatsOrThrow(String) - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- getStatus(GetStatusPRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
-
get file status.
- getStatus(GetStatusPRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- getStatus() - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
-
- getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
-
- getStatus(String, GetStatusPOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
-
Get status.
- getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
-
- getStatus(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
-
- getStatus(AlluxioURI, GetStatusPOptions) - Method in interface alluxio.client.file.FileSystem
-
Gets the
URIStatus
object that represents the metadata of an Alluxio path.
- getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- getStatus(AlluxioURI, GetStatusPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
- getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.MetadataCachingFileSystem
-
- getStatus() - Method in class alluxio.client.file.options.InStreamOptions
-
- getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- getStatus(AlluxioURI) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- getStatus(String, GetStatusOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getStatus() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
-
- getStatus() - Method in exception alluxio.exception.status.AlluxioStatusException
-
- getStatus(int, long) - Method in class alluxio.fsmaster.FileSystemMasterBase
-
- getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
-
Returns the status of the file or directory.
- getStatus(GetStatusPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
-
Returns the status of the file or directory.
- getStatus(GetStatusPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
-
Returns the status of the file or directory.
- getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
-
Returns the status of the file or directory.
- getStatus() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.Status status = 4;
- getStatus() - Method in class alluxio.grpc.CmdSummary
-
optional .alluxio.grpc.job.Status status = 4;
- getStatus() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional .alluxio.grpc.job.Status status = 4;
- getStatus() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
optional .alluxio.grpc.meta.ConfigStatus status = 3;
- getStatus() - Method in class alluxio.grpc.ConfigCheckReport
-
optional .alluxio.grpc.meta.ConfigStatus status = 3;
- getStatus() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
optional .alluxio.grpc.meta.ConfigStatus status = 3;
- getStatus() - Method in class alluxio.grpc.CopyResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in class alluxio.grpc.CopyResponse
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in interface alluxio.grpc.CopyResponseOrBuilder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Returns the status of the file or directory.
- getStatus(GetStatusPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Returns the status of the file or directory.
- getStatus(GetStatusPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Returns the status of the file or directory.
- getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Returns the status of the file or directory.
- getStatus() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- getStatus() - Method in class alluxio.grpc.GetPolicyStatusPResponse
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- getStatus() - Method in interface alluxio.grpc.GetPolicyStatusPResponseOrBuilder
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- getStatus() - Method in class alluxio.grpc.JobInfo.Builder
-
optional .alluxio.grpc.job.Status status = 4;
- getStatus() - Method in class alluxio.grpc.JobInfo
-
optional .alluxio.grpc.job.Status status = 4;
- getStatus() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional .alluxio.grpc.job.Status status = 4;
- getStatus() - Method in class alluxio.grpc.JobProgress.Builder
-
optional .alluxio.grpc.job.Status status = 7;
- getStatus() - Method in class alluxio.grpc.JobProgress
-
optional .alluxio.grpc.job.Status status = 7;
- getStatus() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional .alluxio.grpc.job.Status status = 7;
- getStatus(int) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
repeated .alluxio.grpc.job.Status status = 1;
- getStatus(int) - Method in class alluxio.grpc.ListAllPOptions
-
repeated .alluxio.grpc.job.Status status = 1;
- getStatus(int) - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
-
repeated .alluxio.grpc.job.Status status = 1;
- getStatus() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in class alluxio.grpc.LoadFileResponse
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in class alluxio.grpc.LoadResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in class alluxio.grpc.LoadResponse
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in interface alluxio.grpc.LoadResponseOrBuilder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in class alluxio.grpc.MoveResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in class alluxio.grpc.MoveResponse
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in interface alluxio.grpc.MoveResponseOrBuilder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- getStatus() - Method in class alluxio.grpc.StatusSummary.Builder
-
optional .alluxio.grpc.job.Status status = 1;
- getStatus() - Method in class alluxio.grpc.StatusSummary
-
optional .alluxio.grpc.job.Status status = 1;
- getStatus() - Method in interface alluxio.grpc.StatusSummaryOrBuilder
-
optional .alluxio.grpc.job.Status status = 1;
- getStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- getStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- getStatus() - Method in interface alluxio.grpc.table.SyncDatabasePResponseOrBuilder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- getStatus() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
Deprecated.
- getStatus() - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
Deprecated.
- getStatus() - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
-
Deprecated.
- getStatus() - Method in class alluxio.heartbeat.HeartbeatThread
-
- getStatus() - Method in class alluxio.job.plan.meta.PlanInfo
-
- getStatus() - Method in interface alluxio.job.wire.JobInfo
-
- getStatus() - Method in class alluxio.job.wire.PlanInfo
-
- getStatus() - Method in class alluxio.job.wire.SimpleJobStatusBlock
-
Get status of the job.
- getStatus() - Method in class alluxio.job.wire.StatusSummary
-
Returns the
Status
this object represents.
- getStatus() - Method in class alluxio.job.wire.TaskInfo
-
- getStatus() - Method in class alluxio.job.wire.WorkflowInfo
-
- getStatus() - Method in class alluxio.job.workflow.WorkflowExecution
-
- getStatus(UUID) - Method in class alluxio.master.backup.BackupTracker
-
- getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- getStatus(long) - Method in class alluxio.master.job.JobMaster
-
Gets information of the given job id (verbose = True).
- getStatus(long, boolean) - Method in class alluxio.master.job.JobMaster
-
Gets information of the given job id.
- getStatus(long) - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
-
Gets the job status.
- getStatus(long, boolean) - Method in class alluxio.master.job.workflow.WorkflowTracker
-
Gets information of the given job id.
- getStatus() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional .alluxio.proto.status.PStatus status = 1;
- getStatus() - Method in class alluxio.proto.dataserver.Protocol.Response
-
optional .alluxio.proto.status.PStatus status = 1;
- getStatus() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
-
optional .alluxio.proto.status.PStatus status = 1;
- getStatus(String, GetStatusPOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
-
- getStatus() - Method in class alluxio.s3.S3ErrorCode
-
- getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
-
- getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
-
- getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- getStatus(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- getStatus(AlluxioURI) - Method in class alluxio.underfs.UfsStatusCache
-
Get the UfsStatus from a given AlluxioURI.
- getStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the file or directory status.
- getStatus(String, GetStatusOptions) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the file or directory status.
- getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
-
- getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
-
- getStatusBench(FileSystemMasterBench.FileSystem, FileSystemMasterBench.ThreadState) - Method in class alluxio.fsmaster.FileSystemMasterBench
-
- getStatusBuilder() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- getStatusBuilder() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- getStatusByGrpc(String, GetStatusPOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
-
- getStatusCode() - Method in exception alluxio.exception.status.AlluxioStatusException
-
- getStatusCode() - Method in class alluxio.RestUtils.ErrorResponse
-
Gets status.
- GetStatusContext - Class in alluxio.master.file.contexts
-
- getStatusCount() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
repeated .alluxio.grpc.job.Status status = 1;
- getStatusCount() - Method in class alluxio.grpc.ListAllPOptions
-
repeated .alluxio.grpc.job.Status status = 1;
- getStatusCount() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
-
repeated .alluxio.grpc.job.Status status = 1;
- getStatusCount() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- getStatusCount() - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
- getStatusCount() - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
-
map<string, bool> status = 1;
- getStatusDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- getStatusList() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
repeated .alluxio.grpc.job.Status status = 1;
- getStatusList() - Method in class alluxio.grpc.ListAllPOptions
-
repeated .alluxio.grpc.job.Status status = 1;
- getStatusList() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
-
repeated .alluxio.grpc.job.Status status = 1;
- getStatusMap() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
map<string, bool> status = 1;
- getStatusMap() - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
map<string, bool> status = 1;
- getStatusMap() - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
-
map<string, bool> status = 1;
- GetStatusOptions - Class in alluxio.underfs.options
-
- GetStatusOptions() - Constructor for class alluxio.underfs.options.GetStatusOptions
-
- getStatusOrBuilder() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- getStatusOrBuilder() - Method in class alluxio.grpc.GetPolicyStatusPResponse
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- getStatusOrBuilder() - Method in interface alluxio.grpc.GetPolicyStatusPResponseOrBuilder
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- getStatusOrBuilder() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- getStatusOrBuilder() - Method in class alluxio.grpc.table.SyncDatabasePResponse
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- getStatusOrBuilder() - Method in interface alluxio.grpc.table.SyncDatabasePResponseOrBuilder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- getStatusOrDefault(String, boolean) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
map<string, bool> status = 1;
- getStatusOrDefault(String, boolean) - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
map<string, bool> status = 1;
- getStatusOrDefault(String, boolean) - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
-
map<string, bool> status = 1;
- getStatusOrThrow(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
map<string, bool> status = 1;
- getStatusOrThrow(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
map<string, bool> status = 1;
- getStatusOrThrow(String) - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
-
map<string, bool> status = 1;
- GetStatusPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStatusPOptions
- GetStatusPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStatusPOptions
- GetStatusPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetStatusPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStatusPRequest
- GetStatusPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStatusPRequest
- GetStatusPRequestOrBuilder - Interface in alluxio.grpc
-
- GetStatusPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStatusPResponse
- GetStatusPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetStatusPResponse
- GetStatusPResponseOrBuilder - Interface in alluxio.grpc
-
- getStatusSummary() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Get status summary.
- getStealCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns an estimate of the total number of tasks stolen from one thread's work queue by
another.
- getStopJobMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getStopwatch() - Method in class alluxio.proxy.s3.S3Handler
-
Get Stopwatch object used for recording this request's latency.
- getStopwatch() - Method in class alluxio.worker.s3.S3NettyHandler
-
Get Stopwatch object used for recording this request's latency.
- getStorage(int) - Method in class alluxio.grpc.StorageList.Builder
-
a lost storage path
- getStorage(int) - Method in class alluxio.grpc.StorageList
-
a lost storage path
- getStorage(int) - Method in interface alluxio.grpc.StorageListOrBuilder
-
a lost storage path
- getStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- getStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- getStorage() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- getStorageBuilder() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- getStorageBytes(int) - Method in class alluxio.grpc.StorageList.Builder
-
a lost storage path
- getStorageBytes(int) - Method in class alluxio.grpc.StorageList
-
a lost storage path
- getStorageBytes(int) - Method in interface alluxio.grpc.StorageListOrBuilder
-
a lost storage path
- getStorageClass() - Method in class alluxio.proxy.s3.ListPartsResult
-
- getStorageCount() - Method in class alluxio.grpc.StorageList.Builder
-
a lost storage path
- getStorageCount() - Method in class alluxio.grpc.StorageList
-
a lost storage path
- getStorageCount() - Method in interface alluxio.grpc.StorageListOrBuilder
-
a lost storage path
- getStorageDirs() - Method in class alluxio.wire.WorkerWebUIOverview
-
Gets storage dirs.
- getStorageDirs() - Method in interface alluxio.worker.block.meta.StorageTier
-
- getStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- getStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- getStorageFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- getStorageFormatBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- getStorageFormatOrBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- getStorageFormatOrBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- getStorageFormatOrBuilder() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- getStorageList() - Method in class alluxio.grpc.StorageList.Builder
-
a lost storage path
- getStorageList() - Method in class alluxio.grpc.StorageList
-
a lost storage path
- getStorageList() - Method in interface alluxio.grpc.StorageListOrBuilder
-
a lost storage path
- getStorageOrBuilder() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- getStorageOrBuilder() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- getStorageOrBuilder() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- getStorageTierAlias() - Method in class alluxio.util.webui.StorageTierInfo
-
Gets storage tier alias.
- getStorageTierAssoc() - Method in interface alluxio.worker.block.BlockStoreMeta
-
- getStorageTierInfos() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets storage tier infos.
- getStorageTiers(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the list of storage tiers
- getStorageTiers(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the list of storage tiers
- getStorageTiers(int) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the list of storage tiers
- getStorageTiersBytes(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the list of storage tiers
- getStorageTiersBytes(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the list of storage tiers
- getStorageTiersBytes(int) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the list of storage tiers
- getStorageTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the list of storage tiers
- getStorageTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the list of storage tiers
- getStorageTiersCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the list of storage tiers
- getStorageTiersList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the list of storage tiers
- getStorageTiersList() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the list of storage tiers
- getStorageTiersList() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the list of storage tiers
- getStoreDirOfFile(String) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
-
- getStoreDirOfFile(String) - Method in interface alluxio.client.file.cache.PageMetaStore
-
Gets the store dir which the specified file is assigned to be cached in.
- getStoreDirs() - Method in class alluxio.client.file.cache.DefaultPageMetaStore
-
- getStoreDirs() - Method in interface alluxio.client.file.cache.PageMetaStore
-
Gets the storage directories.
- getStoreMeta() - Method in interface alluxio.worker.block.BlockWorker
-
Gets the metadata for the entire block store.
- getStoreMetaFull() - Method in interface alluxio.worker.block.BlockWorker
-
- getStream() - Method in class alluxio.master.journal.checkpoint.CompoundCheckpointFormat.CompoundCheckpointReader.Entry
-
Return a checkpoint stream containing the bytes for this checkpoint.
- getStreamingUploadEnabled() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getString(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the String value for the given key.
- getString(PropertyKey) - Static method in class alluxio.conf.Configuration
-
Gets the String value for the given key.
- getString(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
-
- getString(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
-
- getStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- getStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- getStringStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- getStringStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- getStringStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- getStringStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- getStringStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- getStringTosSign() - Method in class alluxio.s3.auth.AwsAuthInfo
-
- getStringType() - Method in class alluxio.grpc.table.Value.Builder
-
string string_type = 3;
- getStringType() - Method in class alluxio.grpc.table.Value
-
string string_type = 3;
- getStringType() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
string string_type = 3;
- getStringTypeBytes() - Method in class alluxio.grpc.table.Value.Builder
-
string string_type = 3;
- getStringTypeBytes() - Method in class alluxio.grpc.table.Value
-
string string_type = 3;
- getStringTypeBytes() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
string string_type = 3;
- getStringValue() - Method in class alluxio.grpc.MetricValue.Builder
-
optional string stringValue = 2;
- getStringValue() - Method in class alluxio.grpc.MetricValue
-
optional string stringValue = 2;
- getStringValue() - Method in interface alluxio.grpc.MetricValueOrBuilder
-
optional string stringValue = 2;
- getStringValueBytes() - Method in class alluxio.grpc.MetricValue.Builder
-
optional string stringValue = 2;
- getStringValueBytes() - Method in class alluxio.grpc.MetricValue
-
optional string stringValue = 2;
- getStringValueBytes() - Method in interface alluxio.grpc.MetricValueOrBuilder
-
optional string stringValue = 2;
- getSubCommands() - Method in interface alluxio.cli.Command
-
- getSubCommands() - Method in class alluxio.cli.command.MetadataCacheCommand
-
- getSubCommands() - Method in class alluxio.cli.fsadmin.command.JournalCommand
-
- getSubCommands() - Method in class alluxio.cli.fsadmin.command.MetricsCommand
-
- getSubCommands() - Method in class alluxio.cli.fsadmin.command.NodesCommand
-
- getSubCommands() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
-
- getSubject() - Method in class alluxio.ClientContext
-
- getSubject() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional string subject = 2;
- getSubject() - Method in class alluxio.grpc.PAclEntry
-
optional string subject = 2;
- getSubject() - Method in interface alluxio.grpc.PAclEntryOrBuilder
-
optional string subject = 2;
- getSubject() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional string subject = 2;
- getSubject() - Method in class alluxio.proto.shared.Acl.AclEntry
-
optional string subject = 2;
- getSubject() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
-
optional string subject = 2;
- getSubject() - Method in class alluxio.security.authorization.AclEntry
-
- getSubject() - Method in class alluxio.security.user.BaseUserState
-
- getSubject() - Method in interface alluxio.security.user.UserState
-
Returns the Subject for this user.
- getSubjectBytes() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional string subject = 2;
- getSubjectBytes() - Method in class alluxio.grpc.PAclEntry
-
optional string subject = 2;
- getSubjectBytes() - Method in interface alluxio.grpc.PAclEntryOrBuilder
-
optional string subject = 2;
- getSubjectBytes() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional string subject = 2;
- getSubjectBytes() - Method in class alluxio.proto.shared.Acl.AclEntry
-
optional string subject = 2;
- getSubjectBytes() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
-
optional string subject = 2;
- getSubmissionTime() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 submissionTime = 5;
- getSubmissionTime() - Method in class alluxio.grpc.CmdSummary
-
optional int64 submissionTime = 5;
- getSubmissionTime() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional int64 submissionTime = 5;
- getSubmitJobMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getSubmitMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getSuccess() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
TODO(gpang): remove in favor of status
- getSuccess() - Method in class alluxio.grpc.table.AttachDatabasePResponse
-
TODO(gpang): remove in favor of status
- getSuccess() - Method in interface alluxio.grpc.table.AttachDatabasePResponseOrBuilder
-
TODO(gpang): remove in favor of status
- getSuccess() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
optional bool success = 1;
- getSuccess() - Method in class alluxio.grpc.table.DetachDatabasePResponse
-
optional bool success = 1;
- getSuccess() - Method in interface alluxio.grpc.table.DetachDatabasePResponseOrBuilder
-
optional bool success = 1;
- getSuccess() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
TODO(gpang): remove in favor of status
- getSuccess() - Method in class alluxio.grpc.table.SyncDatabasePResponse
-
TODO(gpang): remove in favor of status
- getSuccess() - Method in interface alluxio.grpc.table.SyncDatabasePResponseOrBuilder
-
TODO(gpang): remove in favor of status
- getSummary() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
- getSummary() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- getSummary() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- getSummary() - Method in interface alluxio.grpc.GetJobServiceSummaryPResponseOrBuilder
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- getSummary() - Method in class alluxio.job.util.TimeSeries
-
- getSummary() - Method in class alluxio.master.job.JobMaster
-
Gets summary of the job service.
- getSummaryBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- getSummaryOrBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- getSummaryOrBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- getSummaryOrBuilder() - Method in interface alluxio.grpc.GetJobServiceSummaryPResponseOrBuilder
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- getSummaryPerStatus(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatus(int) - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatus(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatus() - Method in class alluxio.job.wire.JobServiceSummary
-
Returns an unmodifiable collection of summary per job status.
- getSummaryPerStatusBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusCount() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusCount() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusCount() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusList() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusOrBuilder(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSummaryPerStatusOrBuilderList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- getSuperclassFieldPadding() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
-
Returns the quantum field size for a field owned by one of an object's ancestor superclasses
in this JVM.
- getSupportedVersions(String, AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
-
Get a list of supported versions for a particular UFS path.
- getSurplusQueuedTaskCount() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
-
Returns an estimate of how many more locally queued tasks are held by the current worker thread
than there are other worker threads that might steal them, or zero if this thread is not
operating in a ForkJoinPool.
- getSyncDatabaseMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getSyncIntervalMs() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional int64 syncIntervalMs = 1;
- getSyncIntervalMs() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
optional int64 syncIntervalMs = 1;
- getSyncIntervalMs() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
-
optional int64 syncIntervalMs = 1;
- getSyncMetricName(long) - Static method in class alluxio.metrics.MetricKey
-
- getSyncParentNextTime() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool syncParentNextTime = 5;
- getSyncParentNextTime() - Method in class alluxio.grpc.DeletePOptions
-
optional bool syncParentNextTime = 5;
- getSyncParentNextTime() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional bool syncParentNextTime = 5;
- getSyncPathCache() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getSyncpointPath() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- getSyncpointPath() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
-
optional string syncpoint_path = 1;
- getSyncpointPath() - Method in interface alluxio.proto.journal.File.AddSyncPointEntryOrBuilder
-
optional string syncpoint_path = 1;
- getSyncpointPath() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- getSyncpointPath() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
optional string syncpoint_path = 1;
- getSyncpointPath() - Method in interface alluxio.proto.journal.File.RemoveSyncPointEntryOrBuilder
-
optional string syncpoint_path = 1;
- getSyncpointPathBytes() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- getSyncpointPathBytes() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
-
optional string syncpoint_path = 1;
- getSyncpointPathBytes() - Method in interface alluxio.proto.journal.File.AddSyncPointEntryOrBuilder
-
optional string syncpoint_path = 1;
- getSyncpointPathBytes() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- getSyncpointPathBytes() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
optional string syncpoint_path = 1;
- getSyncpointPathBytes() - Method in interface alluxio.proto.journal.File.RemoveSyncPointEntryOrBuilder
-
optional string syncpoint_path = 1;
- getSyncStatus() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- getSyncStatus() - Method in class alluxio.grpc.table.AttachDatabasePResponse
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- getSyncStatus() - Method in interface alluxio.grpc.table.AttachDatabasePResponseOrBuilder
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- getSyncStatusBuilder() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- getSyncStatusOrBuilder() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- getSyncStatusOrBuilder() - Method in class alluxio.grpc.table.AttachDatabasePResponse
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- getSyncStatusOrBuilder() - Method in interface alluxio.grpc.table.AttachDatabasePResponseOrBuilder
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- getSyncTimesForPath(AlluxioURI) - Method in class alluxio.master.file.meta.UfsSyncPathCache
-
Get sync times for a given path if they exist in the cache.
- getSystemGid() - Static method in class alluxio.fuse.AlluxioFuseUtils
-
- getSystemStatus() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets system status.
- getSystemUid() - Static method in class alluxio.fuse.AlluxioFuseUtils
-
- getTable() - Method in class alluxio.client.hive.HiveCacheContext
-
- getTable(String, String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getTable(String, String) - Method in interface alluxio.client.table.TableMasterClient
-
Get table metadata.
- getTable(int) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
repeated string table = 1;
- getTable(int) - Method in class alluxio.grpc.table.GetAllTablesPResponse
-
repeated string table = 1;
- getTable(int) - Method in interface alluxio.grpc.table.GetAllTablesPResponseOrBuilder
-
repeated string table = 1;
- getTable(GetTablePRequest, StreamObserver<GetTablePResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
-
Returns a specific table info
- getTable(GetTablePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
-
Returns a specific table info
- getTable(GetTablePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
-
Returns a specific table info
- getTable(GetTablePRequest, StreamObserver<GetTablePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
-
Returns a specific table info
- getTableBytes(int) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
repeated string table = 1;
- getTableBytes(int) - Method in class alluxio.grpc.table.GetAllTablesPResponse
-
repeated string table = 1;
- getTableBytes(int) - Method in interface alluxio.grpc.table.GetAllTablesPResponseOrBuilder
-
repeated string table = 1;
- getTableColumnStatistics(String, String, List<String>) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getTableColumnStatistics(String, String, List<String>) - Method in interface alluxio.client.table.TableMasterClient
-
Get table column statistics with given database name,
table name and list of column names.
- getTableColumnStatistics(GetTableColumnStatisticsPRequest, StreamObserver<GetTableColumnStatisticsPResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
-
- getTableColumnStatistics(GetTableColumnStatisticsPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
-
- getTableColumnStatistics(GetTableColumnStatisticsPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
-
- getTableColumnStatistics(GetTableColumnStatisticsPRequest, StreamObserver<GetTableColumnStatisticsPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
-
- GetTableColumnStatisticsPRequest - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTableColumnStatisticsPRequest
- GetTableColumnStatisticsPRequest.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTableColumnStatisticsPRequest
- GetTableColumnStatisticsPRequestOrBuilder - Interface in alluxio.grpc.table
-
- GetTableColumnStatisticsPResponse - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTableColumnStatisticsPResponse
- GetTableColumnStatisticsPResponse.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTableColumnStatisticsPResponse
- GetTableColumnStatisticsPResponseOrBuilder - Interface in alluxio.grpc.table
-
- getTableCount() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
repeated string table = 1;
- getTableCount() - Method in class alluxio.grpc.table.GetAllTablesPResponse
-
repeated string table = 1;
- getTableCount() - Method in interface alluxio.grpc.table.GetAllTablesPResponseOrBuilder
-
repeated string table = 1;
- getTableInfo() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- getTableInfo() - Method in class alluxio.grpc.table.GetTablePResponse
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- getTableInfo() - Method in interface alluxio.grpc.table.GetTablePResponseOrBuilder
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- getTableInfoBuilder() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- getTableInfoOrBuilder() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- getTableInfoOrBuilder() - Method in class alluxio.grpc.table.GetTablePResponse
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- getTableInfoOrBuilder() - Method in interface alluxio.grpc.table.GetTablePResponseOrBuilder
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- getTableList() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
repeated string table = 1;
- getTableList() - Method in class alluxio.grpc.table.GetAllTablesPResponse
-
repeated string table = 1;
- getTableList() - Method in interface alluxio.grpc.table.GetAllTablesPResponseOrBuilder
-
repeated string table = 1;
- getTableName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
optional string table_name = 2;
- getTableName() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
optional string table_name = 2;
- getTableName() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.GetTablePRequest
-
optional string table_name = 2;
- getTableName() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string table_name = 4;
- getTableName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
optional string table_name = 4;
- getTableName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
optional string table_name = 4;
- getTableName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.ReadTablePRequest
-
optional string table_name = 2;
- getTableName() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.TableInfo
-
optional string table_name = 2;
- getTableName() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string table_name = 2;
- getTableName() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string table_name = 2;
- getTableName() - Method in class alluxio.grpc.table.TransformTablePRequest
-
optional string table_name = 2;
- getTableName() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
optional string table_name = 2;
- getTableNameBytes() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
optional string table_name = 2;
- getTableNameBytes() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.GetTablePRequest
-
optional string table_name = 2;
- getTableNameBytes() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string table_name = 4;
- getTableNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
optional string table_name = 4;
- getTableNameBytes() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
optional string table_name = 4;
- getTableNameBytes() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.ReadTablePRequest
-
optional string table_name = 2;
- getTableNameBytes() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.TableInfo
-
optional string table_name = 2;
- getTableNameBytes() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string table_name = 2;
- getTableNameBytes() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string table_name = 2;
- getTableNameBytes() - Method in class alluxio.grpc.table.TransformTablePRequest
-
optional string table_name = 2;
- getTableNameBytes() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
-
optional string table_name = 2;
- GetTablePRequest - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTablePRequest
- GetTablePRequest.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTablePRequest
- GetTablePRequestOrBuilder - Interface in alluxio.grpc.table
-
- GetTablePResponse - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTablePResponse
- GetTablePResponse.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTablePResponse
- GetTablePResponseOrBuilder - Interface in alluxio.grpc.table
-
- getTablesErrors() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
Deprecated.
- getTablesErrors() - Method in class alluxio.grpc.table.SyncStatus
-
Deprecated.
- getTablesErrors() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
Deprecated.
- getTablesErrorsCount() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- getTablesErrorsCount() - Method in class alluxio.grpc.table.SyncStatus
-
- getTablesErrorsCount() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
map<string, string> tables_errors = 1;
- getTablesErrorsMap() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
map<string, string> tables_errors = 1;
- getTablesErrorsMap() - Method in class alluxio.grpc.table.SyncStatus
-
map<string, string> tables_errors = 1;
- getTablesErrorsMap() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
map<string, string> tables_errors = 1;
- getTablesErrorsOrDefault(String, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
map<string, string> tables_errors = 1;
- getTablesErrorsOrDefault(String, String) - Method in class alluxio.grpc.table.SyncStatus
-
map<string, string> tables_errors = 1;
- getTablesErrorsOrDefault(String, String) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
map<string, string> tables_errors = 1;
- getTablesErrorsOrThrow(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
map<string, string> tables_errors = 1;
- getTablesErrorsOrThrow(String) - Method in class alluxio.grpc.table.SyncStatus
-
map<string, string> tables_errors = 1;
- getTablesErrorsOrThrow(String) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
map<string, string> tables_errors = 1;
- getTablesIgnored(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_ignored = 2;
- getTablesIgnored(int) - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_ignored = 2;
- getTablesIgnored(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_ignored = 2;
- getTablesIgnoredBytes(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_ignored = 2;
- getTablesIgnoredBytes(int) - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_ignored = 2;
- getTablesIgnoredBytes(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_ignored = 2;
- getTablesIgnoredCount() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_ignored = 2;
- getTablesIgnoredCount() - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_ignored = 2;
- getTablesIgnoredCount() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_ignored = 2;
- getTablesIgnoredList() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_ignored = 2;
- getTablesIgnoredList() - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_ignored = 2;
- getTablesIgnoredList() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_ignored = 2;
- getTablesRemoved(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_removed = 5;
- getTablesRemoved(int) - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_removed = 5;
- getTablesRemoved(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_removed = 5;
- getTablesRemovedBytes(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_removed = 5;
- getTablesRemovedBytes(int) - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_removed = 5;
- getTablesRemovedBytes(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_removed = 5;
- getTablesRemovedCount() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_removed = 5;
- getTablesRemovedCount() - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_removed = 5;
- getTablesRemovedCount() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_removed = 5;
- getTablesRemovedList() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_removed = 5;
- getTablesRemovedList() - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_removed = 5;
- getTablesRemovedList() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_removed = 5;
- getTablesUnchanged(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_unchanged = 3;
- getTablesUnchanged(int) - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_unchanged = 3;
- getTablesUnchanged(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_unchanged = 3;
- getTablesUnchangedBytes(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_unchanged = 3;
- getTablesUnchangedBytes(int) - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_unchanged = 3;
- getTablesUnchangedBytes(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_unchanged = 3;
- getTablesUnchangedCount() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_unchanged = 3;
- getTablesUnchangedCount() - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_unchanged = 3;
- getTablesUnchangedCount() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_unchanged = 3;
- getTablesUnchangedList() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_unchanged = 3;
- getTablesUnchangedList() - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_unchanged = 3;
- getTablesUnchangedList() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_unchanged = 3;
- getTablesUpdated(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_updated = 4;
- getTablesUpdated(int) - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_updated = 4;
- getTablesUpdated(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_updated = 4;
- getTablesUpdatedBytes(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_updated = 4;
- getTablesUpdatedBytes(int) - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_updated = 4;
- getTablesUpdatedBytes(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_updated = 4;
- getTablesUpdatedCount() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_updated = 4;
- getTablesUpdatedCount() - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_updated = 4;
- getTablesUpdatedCount() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_updated = 4;
- getTablesUpdatedList() - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_updated = 4;
- getTablesUpdatedList() - Method in class alluxio.grpc.table.SyncStatus
-
repeated string tables_updated = 4;
- getTablesUpdatedList() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
repeated string tables_updated = 4;
- getTag() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
required string tag = 1;
- getTag() - Method in class alluxio.grpc.UfsReadOptions
-
required string tag = 1;
- getTag() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
-
required string tag = 1;
- getTag(Fingerprint.Tag) - Method in class alluxio.underfs.Fingerprint
-
- getTagBytes() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
required string tag = 1;
- getTagBytes() - Method in class alluxio.grpc.UfsReadOptions
-
required string tag = 1;
- getTagBytes() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
-
required string tag = 1;
- getTagMap() - Method in class alluxio.s3.TaggingData
-
Returns the Map object containing the contents of
the TagSet.
- getTags() - Method in class alluxio.grpc.Metric.Builder
-
Deprecated.
- getTags() - Method in class alluxio.grpc.Metric
-
Deprecated.
- getTags() - Method in interface alluxio.grpc.MetricOrBuilder
-
Deprecated.
- getTags() - Method in class alluxio.metrics.Metric
-
- getTagsCount() - Method in class alluxio.grpc.Metric.Builder
-
- getTagsCount() - Method in class alluxio.grpc.Metric
-
- getTagsCount() - Method in interface alluxio.grpc.MetricOrBuilder
-
map<string, string> tags = 6;
- getTagsMap() - Method in class alluxio.grpc.Metric.Builder
-
map<string, string> tags = 6;
- getTagsMap() - Method in class alluxio.grpc.Metric
-
map<string, string> tags = 6;
- getTagsMap() - Method in interface alluxio.grpc.MetricOrBuilder
-
map<string, string> tags = 6;
- getTagsOrDefault(String, String) - Method in class alluxio.grpc.Metric.Builder
-
map<string, string> tags = 6;
- getTagsOrDefault(String, String) - Method in class alluxio.grpc.Metric
-
map<string, string> tags = 6;
- getTagsOrDefault(String, String) - Method in interface alluxio.grpc.MetricOrBuilder
-
map<string, string> tags = 6;
- getTagsOrThrow(String) - Method in class alluxio.grpc.Metric.Builder
-
map<string, string> tags = 6;
- getTagsOrThrow(String) - Method in class alluxio.grpc.Metric
-
map<string, string> tags = 6;
- getTagsOrThrow(String) - Method in interface alluxio.grpc.MetricOrBuilder
-
map<string, string> tags = 6;
- getTagsPerBucket() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
-
- getTagUfsValueFromFullName(String) - Static method in class alluxio.metrics.Metric
-
Gets value of ufs tag from the full metric name.
- getTargetBuffer() - Method in class alluxio.file.NettyBufTargetBuffer
-
Get the internal Bytebuf object.
- getTargetDirectory() - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional string targetDirectory = 2;
- getTargetDirectory() - Method in class alluxio.grpc.BackupPRequest
-
optional string targetDirectory = 2;
- getTargetDirectory() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
-
optional string targetDirectory = 2;
- getTargetDirectoryBytes() - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional string targetDirectory = 2;
- getTargetDirectoryBytes() - Method in class alluxio.grpc.BackupPRequest
-
optional string targetDirectory = 2;
- getTargetDirectoryBytes() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
-
optional string targetDirectory = 2;
- getTaskArgs() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional bytes taskArgs = 4;
- getTaskArgs() - Method in class alluxio.grpc.RunTaskCommand
-
optional bytes taskArgs = 4;
- getTaskArgs() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
-
optional bytes taskArgs = 4;
- getTaskExecutorPoolSize() - Method in class alluxio.worker.job.task.TaskExecutorManager
-
- getTaskId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
optional int64 taskId = 2;
- getTaskId() - Method in class alluxio.grpc.CancelTaskCommand
-
optional int64 taskId = 2;
- getTaskId() - Method in interface alluxio.grpc.CancelTaskCommandOrBuilder
-
optional int64 taskId = 2;
- getTaskId() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional int64 taskId = 2;
- getTaskId() - Method in class alluxio.grpc.RunTaskCommand
-
optional int64 taskId = 2;
- getTaskId() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
-
optional int64 taskId = 2;
- getTaskId() - Method in class alluxio.job.RunTaskContext
-
- getTaskId() - Method in class alluxio.job.wire.TaskInfo
-
- getTaskId() - Method in class alluxio.scheduler.job.Task
-
Get task id.
- getTaskIdList() - Method in class alluxio.job.plan.meta.PlanInfo
-
- getTaskInfo(long) - Method in class alluxio.job.plan.meta.PlanInfo
-
- getTaskInfoList() - Method in class alluxio.job.plan.meta.PlanInfo
-
- getTaskInfos(int) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfos(int) - Method in class alluxio.grpc.JobHeartbeatPRequest
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfos(int) - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosBuilderList() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosCount() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosCount() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosCount() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosList() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosList() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosList() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosOrBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosOrBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPRequest
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosOrBuilder(int) - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosOrBuilderList() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosOrBuilderList() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskInfosOrBuilderList() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- getTaskPoolSize() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 taskPoolSize = 5;
- getTaskPoolSize() - Method in class alluxio.grpc.JobWorkerHealth
-
optional int32 taskPoolSize = 5;
- getTaskPoolSize() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional int32 taskPoolSize = 5;
- getTaskPoolSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
optional int32 taskPoolSize = 1;
- getTaskPoolSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
-
optional int32 taskPoolSize = 1;
- getTaskPoolSize() - Method in interface alluxio.grpc.SetTaskPoolSizeCommandOrBuilder
-
optional int32 taskPoolSize = 1;
- getTaskPoolSize() - Method in class alluxio.job.wire.JobWorkerHealth
-
- getTasks() - Method in class alluxio.cli.HdfsValidationTool
-
- getTasks() - Method in class alluxio.cli.HmsValidationTool
-
- getTasks() - Method in class alluxio.cli.ValidateEnv
-
Get the tasks registered.
- getTasks() - Method in interface alluxio.cli.ValidationTool
-
- getTaskStat() - Method in class alluxio.scheduler.job.Task
-
- getTempBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
-
Gets the temp metadata of a specific block from local storage.
- getTempBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
-
- getTemporaryCheckpoints() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
-
- getTemporaryToken(String, String, String, Mode.Bits) - Method in interface alluxio.underfs.UnderFileSystem
-
Gets a temporary token according to path, sid, effect and action.
- getTempUfsPath() - Method in class alluxio.master.file.meta.InodeFile
-
- getTempUfsPath() - Method in interface alluxio.master.file.meta.InodeFileView
-
- getTempUfsPath() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getTempUfsPath() - Method in class alluxio.master.file.PersistJob
-
- getTempUfsPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string temp_ufs_path = 23;
- getTempUfsPath() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string temp_ufs_path = 23;
- getTempUfsPath() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string temp_ufs_path = 23;
- getTempUfsPath() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string tempUfsPath = 12;
- getTempUfsPath() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string tempUfsPath = 12;
- getTempUfsPath() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string tempUfsPath = 12;
- getTempUfsPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string temp_ufs_path = 11;
- getTempUfsPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional string temp_ufs_path = 11;
- getTempUfsPath() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional string temp_ufs_path = 11;
- getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string temp_ufs_path = 23;
- getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string temp_ufs_path = 23;
- getTempUfsPathBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string temp_ufs_path = 23;
- getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string tempUfsPath = 12;
- getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string tempUfsPath = 12;
- getTempUfsPathBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string tempUfsPath = 12;
- getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string temp_ufs_path = 11;
- getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional string temp_ufs_path = 11;
- getTempUfsPathBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional string temp_ufs_path = 11;
- getThis() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getThis() - Method in class alluxio.master.file.meta.MutableInode
-
- getThis() - Method in class alluxio.master.file.meta.MutableInodeDirectory
-
- getThis() - Method in class alluxio.master.file.meta.MutableInodeFile
-
- getThread(ExecutorService) - Static method in class alluxio.master.transport.GrpcMessagingContext
-
Gets the thread from a single threaded executor service.
- getThreadCountIoMbps() - Method in class alluxio.stress.client.ClientIOSummary
-
- getThreadCountResults() - Method in class alluxio.stress.client.ClientIOTaskResult
-
- getThreadIdentifier(Thread) - Static method in class alluxio.util.ThreadUtils
-
- getThreadName() - Method in class alluxio.heartbeat.ScheduledTimer
-
- getThreadNames() - Static method in class alluxio.heartbeat.HeartbeatScheduler
-
- getThreads(int) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
repeated string threads = 1;
- getThreads(int) - Method in class alluxio.grpc.GetStateLockHoldersPResponse
-
repeated string threads = 1;
- getThreads(int) - Method in interface alluxio.grpc.GetStateLockHoldersPResponseOrBuilder
-
repeated string threads = 1;
- getThreadsBytes(int) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
repeated string threads = 1;
- getThreadsBytes(int) - Method in class alluxio.grpc.GetStateLockHoldersPResponse
-
repeated string threads = 1;
- getThreadsBytes(int) - Method in interface alluxio.grpc.GetStateLockHoldersPResponseOrBuilder
-
repeated string threads = 1;
- getThreadsCount() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
repeated string threads = 1;
- getThreadsCount() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
-
repeated string threads = 1;
- getThreadsCount() - Method in interface alluxio.grpc.GetStateLockHoldersPResponseOrBuilder
-
repeated string threads = 1;
- getThreadsList() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
repeated string threads = 1;
- getThreadsList() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
-
repeated string threads = 1;
- getThreadsList() - Method in interface alluxio.grpc.GetStateLockHoldersPResponseOrBuilder
-
repeated string threads = 1;
- getThroughput() - Method in class alluxio.stress.common.GeneralBenchSummary
-
- getThroughput() - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
-
- getThroughputPercentiles() - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- getThroughputPercentiles() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- getTid() - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
-
- getTier() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
This is only applicable for block write.
- getTier() - Method in class alluxio.grpc.WriteRequestCommand
-
This is only applicable for block write.
- getTier() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
This is only applicable for block write.
- getTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int32 tier = 3;
- getTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
optional int32 tier = 3;
- getTier() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
-
optional int32 tier = 3;
- getTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for block write.
- getTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
This is only applicable for block write.
- getTier() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
This is only applicable for block write.
- getTier() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string tier = 2;
- getTier() - Method in class alluxio.proto.meta.Block.BlockLocation
-
optional string tier = 2;
- getTier() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
-
optional string tier = 2;
- getTier() - Method in class alluxio.worker.netty.BlockWriteRequest
-
- getTierAlias() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string tierAlias = 3;
- getTierAlias() - Method in class alluxio.grpc.BlockLocation
-
optional string tierAlias = 3;
- getTierAlias() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional string tierAlias = 3;
- getTierAlias() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string tierAlias = 1;
- getTierAlias() - Method in class alluxio.grpc.BlockStoreLocationProto
-
optional string tierAlias = 1;
- getTierAlias() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
-
optional string tierAlias = 1;
- getTierAlias() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the alias of the target tier
- getTierAlias() - Method in class alluxio.grpc.CommitBlockPRequest
-
the alias of the target tier
- getTierAlias() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the alias of the target tier
- getTierAlias() - Method in class alluxio.master.block.meta.MasterBlockLocation
-
- getTierAlias() - Method in class alluxio.util.webui.UIStorageDir
-
Gets tier alias.
- getTierAlias() - Method in class alluxio.util.webui.UIUsageOnTier
-
Gets tier alias.
- getTierAlias() - Method in class alluxio.wire.BlockLocation
-
- getTierAlias() - Method in interface alluxio.worker.block.meta.StorageTier
-
- getTierAliasBytes() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string tierAlias = 3;
- getTierAliasBytes() - Method in class alluxio.grpc.BlockLocation
-
optional string tierAlias = 3;
- getTierAliasBytes() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional string tierAlias = 3;
- getTierAliasBytes() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string tierAlias = 1;
- getTierAliasBytes() - Method in class alluxio.grpc.BlockStoreLocationProto
-
optional string tierAlias = 1;
- getTierAliasBytes() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
-
optional string tierAlias = 1;
- getTierAliasBytes() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the alias of the target tier
- getTierAliasBytes() - Method in class alluxio.grpc.CommitBlockPRequest
-
the alias of the target tier
- getTierAliasBytes() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the alias of the target tier
- getTierBytes() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string tier = 2;
- getTierBytes() - Method in class alluxio.proto.meta.Block.BlockLocation
-
optional string tier = 2;
- getTierBytes() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
-
optional string tier = 2;
- getTierCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getTierCapacity() - Method in class alluxio.wire.AlluxioWorkerInfo
-
- getTierOrdinal() - Method in interface alluxio.worker.block.meta.StorageTier
-
- getTierPaths() - Method in class alluxio.wire.AlluxioWorkerInfo
-
- getTiers(int) - Method in class alluxio.grpc.TierList.Builder
-
repeated int64 tiers = 1;
- getTiers(int) - Method in class alluxio.grpc.TierList
-
repeated int64 tiers = 1;
- getTiers(int) - Method in interface alluxio.grpc.TierListOrBuilder
-
repeated int64 tiers = 1;
- getTiersCount() - Method in class alluxio.grpc.TierList.Builder
-
repeated int64 tiers = 1;
- getTiersCount() - Method in class alluxio.grpc.TierList
-
repeated int64 tiers = 1;
- getTiersCount() - Method in interface alluxio.grpc.TierListOrBuilder
-
repeated int64 tiers = 1;
- getTiersList() - Method in class alluxio.grpc.TierList.Builder
-
repeated int64 tiers = 1;
- getTiersList() - Method in class alluxio.grpc.TierList
-
repeated int64 tiers = 1;
- getTiersList() - Method in interface alluxio.grpc.TierListOrBuilder
-
repeated int64 tiers = 1;
- getTimedOutSessions() - Method in class alluxio.Sessions
-
Gets the sessions that timed out.
- getTimeExpression() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string timeExpression = 4;
- getTimeExpression() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string timeExpression = 4;
- getTimeExpression() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string timeExpression = 4;
- getTimeExpressionBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string timeExpression = 4;
- getTimeExpressionBytes() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string timeExpression = 4;
- getTimeExpressionBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string timeExpression = 4;
- getTimeNs() - Method in class alluxio.stress.cli.Benchmark.MethodStatistics
-
- getTimeoutDuration() - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- getTimeoutMs() - Method in class alluxio.network.netty.NettyRPCContext
-
- getTimeoutMs() - Method in class alluxio.util.WaitForOptions
-
- getTimeoutThreads() - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- getTimer() - Method in class alluxio.master.file.PersistJob
-
- getTimerClass(String) - Static method in class alluxio.heartbeat.HeartbeatContext
-
- getTimerClasses() - Static method in class alluxio.heartbeat.HeartbeatContext
-
- getTimeSeries() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getTimeSeries() - Method in interface alluxio.master.file.FileSystemMaster
-
- getTimeSeries() - Method in class alluxio.master.metrics.TimeSeriesStore
-
- getTimeSeriesMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
-
- getTimeStamp() - Method in class alluxio.metrics.TimeSeries.DataPoint
-
- getTimestampGetter() - Method in class alluxio.master.predicate.DatePredicate.Factory
-
- getTimestampGetter() - Method in class alluxio.master.predicate.DatePredicate.LastModifiedDateFactory
-
- getTimestampGetter() - Method in class alluxio.master.predicate.TimePredicate.Factory
-
- getTimestampGetter() - Method in class alluxio.master.predicate.TimePredicate.UnmodifiedForFactory
-
- getTimeToFirstBytePerThread() - Method in class alluxio.stress.client.ClientIOTaskResult
-
- getTitle() - Method in class alluxio.stress.graph.Graph
-
- getTmpDir() - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
-
- getTmpDir(List<String>) - Static method in class alluxio.util.CommonUtils
-
- getToBePersistedIds() - Method in class alluxio.master.file.meta.InodeTree
-
- getToBePersistedIds() - Method in class alluxio.master.file.meta.InodeTreePersistentState
-
- getToDelete() - Method in class alluxio.s3.DeleteObjectsRequest
-
- getToRemoveBlockCount() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
Returns the number of blocks that should be removed from the worker.
- getToRemoveBlocks() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- getTotal() - Method in class alluxio.wire.Capacity
-
- getTotalAllocatedBytes() - Method in class alluxio.wire.JournalDiskInfo
-
- getTotalBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
Deprecated.
- getTotalBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
Deprecated.
- getTotalBytesOnTiers() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
Deprecated.
- getTotalBytesOnTiers() - Method in interface alluxio.master.block.BlockMaster
-
- getTotalBytesOnTiers() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getTotalBytesOnTiers() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- getTotalBytesOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- getTotalBytesOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
- getTotalBytesOnTiersCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of total bytes on each tier
- getTotalBytesOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of total bytes on each tier
- getTotalBytesOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of total bytes on each tier
- getTotalBytesOnTiersMap() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of total bytes on each tier
- getTotalBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of total bytes on each tier
- getTotalBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of total bytes on each tier
- getTotalBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of total bytes on each tier
- getTotalBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of total bytes on each tier
- getTotalBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of total bytes on each tier
- getTotalBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of total bytes on each tier
- getTotalBytesReadDomainSocket() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes read from domain socket.
- getTotalBytesReadDomainSocketThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes read from domain socket throughput.
- getTotalBytesReadRemote() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes read remote.
- getTotalBytesReadRemoteThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes read remote throughput.
- getTotalBytesReadUfs() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes read ufs.
- getTotalBytesReadUfsThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes read ufs throughput.
- getTotalBytesWrittenDomainSocket() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes written through domain socket.
- getTotalBytesWrittenDomainSocketThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes written through domain socket throughput.
- getTotalBytesWrittenRemote() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes written remote.
- getTotalBytesWrittenRemoteThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes written remote throughput.
- getTotalBytesWrittenUfs() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes written ufs.
- getTotalBytesWrittenUfsThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets total bytes written ufs throughput.
- getTotalCapacityOnTiers() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get capacity by tiers.
- getTotalExtraTime() - Method in class alluxio.util.JvmPauseMonitor
-
- getTotalListings() - Method in class alluxio.master.file.contexts.ListStatusContext
-
Get the value set by setTotalListing.
- getTotalPath() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets total path.
- getTransferId() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
required string transferId = 1;
- getTransferId() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
-
required string transferId = 1;
- getTransferId() - Method in interface alluxio.grpc.GetTransferLeaderMessagePRequestOrBuilder
-
required string transferId = 1;
- getTransferId() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
required string transferId = 1;
- getTransferId() - Method in class alluxio.grpc.TransferLeadershipPResponse
-
required string transferId = 1;
- getTransferId() - Method in interface alluxio.grpc.TransferLeadershipPResponseOrBuilder
-
required string transferId = 1;
- getTransferIdBytes() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
required string transferId = 1;
- getTransferIdBytes() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
-
required string transferId = 1;
- getTransferIdBytes() - Method in interface alluxio.grpc.GetTransferLeaderMessagePRequestOrBuilder
-
required string transferId = 1;
- getTransferIdBytes() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
required string transferId = 1;
- getTransferIdBytes() - Method in class alluxio.grpc.TransferLeadershipPResponse
-
required string transferId = 1;
- getTransferIdBytes() - Method in interface alluxio.grpc.TransferLeadershipPResponseOrBuilder
-
required string transferId = 1;
- getTransferLeaderMessage(String) - Method in interface alluxio.client.journal.JournalMasterClient
-
Gets exception messages thrown when transferring the leader.
- getTransferLeaderMessage(String) - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
-
- getTransferLeaderMessage(GetTransferLeaderMessagePRequest, StreamObserver<GetTransferLeaderMessagePResponse>) - Method in interface alluxio.grpc.JournalMasterClientServiceGrpc.AsyncService
-
Gets exception message throwing when transfer leader.
- getTransferLeaderMessage(GetTransferLeaderMessagePRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub
-
Gets exception message throwing when transfer leader.
- getTransferLeaderMessage(GetTransferLeaderMessagePRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub
-
Gets exception message throwing when transfer leader.
- getTransferLeaderMessage(GetTransferLeaderMessagePRequest, StreamObserver<GetTransferLeaderMessagePResponse>) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceStub
-
Gets exception message throwing when transfer leader.
- getTransferLeaderMessage(GetTransferLeaderMessagePRequest, StreamObserver<GetTransferLeaderMessagePResponse>) - Method in class alluxio.master.journal.JournalMasterClientServiceHandler
-
- GetTransferLeaderMessageOptions - Class in alluxio.grpc
-
GetTransferLeaderMessage API
- GetTransferLeaderMessageOptions.Builder - Class in alluxio.grpc
-
GetTransferLeaderMessage API
- GetTransferLeaderMessageOptionsOrBuilder - Interface in alluxio.grpc
-
- GetTransferLeaderMessagePRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetTransferLeaderMessagePRequest
- GetTransferLeaderMessagePRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetTransferLeaderMessagePRequest
- GetTransferLeaderMessagePRequestOrBuilder - Interface in alluxio.grpc
-
- GetTransferLeaderMessagePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetTransferLeaderMessagePResponse
- GetTransferLeaderMessagePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.journal.GetTransferLeaderMessagePResponse
- GetTransferLeaderMessagePResponseOrBuilder - Interface in alluxio.grpc
-
- getTransferLeadershipMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
-
- getTransferManager() - Method in class alluxio.underfs.s3a.S3AOutputStream
-
- getTransferManager() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getTransformations(int) - Method in class alluxio.grpc.table.Partition.Builder
-
The latest transformation is in the back of the list.
- getTransformations(int) - Method in class alluxio.grpc.table.Partition
-
The latest transformation is in the back of the list.
- getTransformations(int) - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
The latest transformation is in the back of the list.
- getTransformationsBuilder(int) - Method in class alluxio.grpc.table.Partition.Builder
-
The latest transformation is in the back of the list.
- getTransformationsBuilderList() - Method in class alluxio.grpc.table.Partition.Builder
-
The latest transformation is in the back of the list.
- getTransformationsCount() - Method in class alluxio.grpc.table.Partition.Builder
-
The latest transformation is in the back of the list.
- getTransformationsCount() - Method in class alluxio.grpc.table.Partition
-
The latest transformation is in the back of the list.
- getTransformationsCount() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
The latest transformation is in the back of the list.
- getTransformationsList() - Method in class alluxio.grpc.table.Partition.Builder
-
The latest transformation is in the back of the list.
- getTransformationsList() - Method in class alluxio.grpc.table.Partition
-
The latest transformation is in the back of the list.
- getTransformationsList() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
The latest transformation is in the back of the list.
- getTransformationsOrBuilder(int) - Method in class alluxio.grpc.table.Partition.Builder
-
The latest transformation is in the back of the list.
- getTransformationsOrBuilder(int) - Method in class alluxio.grpc.table.Partition
-
The latest transformation is in the back of the list.
- getTransformationsOrBuilder(int) - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
The latest transformation is in the back of the list.
- getTransformationsOrBuilderList() - Method in class alluxio.grpc.table.Partition.Builder
-
The latest transformation is in the back of the list.
- getTransformationsOrBuilderList() - Method in class alluxio.grpc.table.Partition
-
The latest transformation is in the back of the list.
- getTransformationsOrBuilderList() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
The latest transformation is in the back of the list.
- getTransformJobInfo(long) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getTransformJobInfo(long) - Method in interface alluxio.client.table.TableMasterClient
-
- getTransformJobInfo(GetTransformJobInfoPRequest, StreamObserver<GetTransformJobInfoPResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
-
Gets information of transformation jobs.
- getTransformJobInfo(GetTransformJobInfoPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
-
Gets information of transformation jobs.
- getTransformJobInfo(GetTransformJobInfoPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
-
Gets information of transformation jobs.
- getTransformJobInfo(GetTransformJobInfoPRequest, StreamObserver<GetTransformJobInfoPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
-
Gets information of transformation jobs.
- GetTransformJobInfoPRequest - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTransformJobInfoPRequest
- GetTransformJobInfoPRequest.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTransformJobInfoPRequest
- GetTransformJobInfoPRequestOrBuilder - Interface in alluxio.grpc.table
-
- GetTransformJobInfoPResponse - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTransformJobInfoPResponse
- GetTransformJobInfoPResponse.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.GetTransformJobInfoPResponse
- GetTransformJobInfoPResponseOrBuilder - Interface in alluxio.grpc.table
-
- getTransformTableMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- getTransMsg() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- getTransMsg() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- getTransMsg() - Method in interface alluxio.grpc.GetTransferLeaderMessagePResponseOrBuilder
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- getTransMsgBuilder() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- getTransMsgOrBuilder() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- getTransMsgOrBuilder() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- getTransMsgOrBuilder() - Method in interface alluxio.grpc.GetTransferLeaderMessagePResponseOrBuilder
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- getTriggerEventsWithParam() - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
-
Get the TriggerEventsWithParam.
- getTriggerPolicyMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
-
- getTs() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
the timestamp in nanoseconds when this FileStatus is refreshed
- getTs() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
-
the timestamp in nanoseconds when this FileStatus is refreshed
- getTs() - Method in interface alluxio.proto.meta.DoraMeta.FileStatusOrBuilder
-
the timestamp in nanoseconds when this FileStatus is refreshed
- getTtl() - Method in class alluxio.client.file.URIStatus
-
- getTtl() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 ttl = 15;
- getTtl() - Method in class alluxio.grpc.FileInfo
-
optional int64 ttl = 15;
- getTtl() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 ttl = 15;
- getTtl() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional int64 ttl = 2;
- getTtl() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
optional int64 ttl = 2;
- getTtl() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
-
optional int64 ttl = 2;
- getTtl() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getTtl() - Method in class alluxio.master.file.meta.Inode
-
- getTtl() - Method in interface alluxio.master.file.meta.InodeView
-
- getTtl() - Method in class alluxio.master.file.meta.MutableInode
-
- getTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 ttl = 13;
- getTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 ttl = 13;
- getTtl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 ttl = 13;
- getTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 ttl = 13;
- getTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 ttl = 13;
- getTtl() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 ttl = 13;
- getTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 ttl = 4;
- getTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int64 ttl = 4;
- getTtl() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int64 ttl = 4;
- getTtl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 ttl = 12;
- getTtl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 ttl = 12;
- getTtl() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 ttl = 12;
- getTtl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 ttl = 4;
- getTtl() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 ttl = 4;
- getTtl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 ttl = 4;
- getTtl() - Method in class alluxio.wire.FileInfo
-
- getTtlAction() - Method in class alluxio.client.file.URIStatus
-
- getTtlAction() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.TtlAction ttlAction = 22;
- getTtlAction() - Method in class alluxio.grpc.FileInfo
-
optional .alluxio.grpc.TtlAction ttlAction = 22;
- getTtlAction() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional .alluxio.grpc.TtlAction ttlAction = 22;
- getTtlAction() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.TtlAction ttlAction = 3;
- getTtlAction() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
optional .alluxio.grpc.TtlAction ttlAction = 3;
- getTtlAction() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
-
optional .alluxio.grpc.TtlAction ttlAction = 3;
- getTtlAction() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getTtlAction() - Method in class alluxio.master.file.meta.Inode
-
- getTtlAction() - Method in interface alluxio.master.file.meta.InodeView
-
- getTtlAction() - Method in class alluxio.master.file.meta.MutableInode
-
- getTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
- getTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
- getTtlAction() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
- getTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
- getTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
- getTtlAction() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
- getTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
- getTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
- getTtlAction() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
- getTtlAction() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
- getTtlAction() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
- getTtlAction() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
- getTtlAction() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.grpc.TtlAction ttl_action = 5;
- getTtlAction() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional .alluxio.grpc.TtlAction ttl_action = 5;
- getTtlAction() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional .alluxio.grpc.TtlAction ttl_action = 5;
- getTtlAction() - Method in class alluxio.wire.FileInfo
-
- getTtlBuckets() - Method in class alluxio.master.file.meta.InodeTree
-
- getTtlBuckets() - Method in class alluxio.master.file.meta.InodeTreePersistentState
-
- getTtlCheckIntervalSeconds() - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- getTtlIntervalEndTimeMs() - Method in class alluxio.master.file.meta.TtlBucket
-
- getTtlIntervalMs() - Static method in class alluxio.master.file.meta.TtlBucket
-
- getTtlIntervalStartTimeMs() - Method in class alluxio.master.file.meta.TtlBucket
-
- getTtlThresholdSeconds() - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- getTxId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
optional int64 tx_id = 2;
- getTxId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
optional int64 tx_id = 2;
- getTxId() - Method in interface alluxio.proto.journal.File.ActiveSyncTxIdEntryOrBuilder
-
optional int64 tx_id = 2;
- getType() - Method in class alluxio.cli.HdfsValidationToolFactory
-
- getType() - Method in class alluxio.cli.HmsValidationToolFactory
-
- getType() - Method in interface alluxio.cli.ValidationToolFactory
-
- getType() - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- getType() - Method in enum alluxio.client.file.dora.netty.PartialReadException.CauseType
-
- getType() - Method in class alluxio.conf.PropertyKey
-
- getType() - Method in class alluxio.conf.Source
-
- getType() - Method in class alluxio.grpc.JobDescription.Builder
-
required string type = 1;
- getType() - Method in class alluxio.grpc.JobDescription
-
required string type = 1;
- getType() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
-
required string type = 1;
- getType() - Method in class alluxio.grpc.JobInfo.Builder
-
optional .alluxio.grpc.job.JobType type = 8;
- getType() - Method in class alluxio.grpc.JobInfo
-
optional .alluxio.grpc.job.JobType type = 8;
- getType() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional .alluxio.grpc.job.JobType type = 8;
- getType() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional .alluxio.grpc.file.PAclEntryType type = 1;
- getType() - Method in class alluxio.grpc.PAclEntry
-
optional .alluxio.grpc.file.PAclEntryType type = 1;
- getType() - Method in interface alluxio.grpc.PAclEntryOrBuilder
-
optional .alluxio.grpc.file.PAclEntryType type = 1;
- getType() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string type = 3;
- getType() - Method in class alluxio.grpc.table.FieldSchema
-
optional string type = 3;
- getType() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional string type = 3;
- getType() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
- getType() - Method in class alluxio.grpc.table.TableInfo
-
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
- getType() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
- getType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional .alluxio.grpc.block.RequestType type = 1;
- getType() - Method in class alluxio.grpc.WriteRequestCommand
-
optional .alluxio.grpc.block.RequestType type = 1;
- getType() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional .alluxio.grpc.block.RequestType type = 1;
- getType() - Method in class alluxio.job.CopyJobRequest
-
- getType() - Method in class alluxio.job.JobDescription
-
- getType() - Method in interface alluxio.job.JobRequest
-
- getType() - Method in class alluxio.job.LoadJobRequest
-
- getType() - Method in class alluxio.job.MoveJobRequest
-
- getType() - Method in interface alluxio.master.file.contexts.CallTracker
-
- getType() - Method in class alluxio.master.file.contexts.GrpcCallTracker
-
- getType() - Method in class alluxio.master.journal.checkpoint.CheckpointInputStream
-
- getType() - Method in interface alluxio.master.selectionpolicy.MasterSelectionPolicy
-
- getType() - Method in class alluxio.master.selectionpolicy.SelectionPolicyAnyMaster
-
- getType() - Method in class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
-
- getType() - Method in class alluxio.master.selectionpolicy.SelectionPolicyPrimaryMaster
-
- getType() - Method in class alluxio.master.selectionpolicy.SelectionPolicySpecifiedMaster
-
- getType() - Method in class alluxio.network.protocol.RPCMessage
-
Returns the type of the message.
- getType() - Method in class alluxio.network.protocol.RPCProtoMessage
-
- getType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
- getType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
-
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
- getType() - Method in interface alluxio.proto.dataserver.Protocol.ReadResponseOrBuilder
-
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
- getType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional .alluxio.proto.dataserver.RequestType type = 1;
- getType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
optional .alluxio.proto.dataserver.RequestType type = 1;
- getType() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
optional .alluxio.proto.dataserver.RequestType type = 1;
- getType() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional .alluxio.proto.shared.AclEntryType type = 1;
- getType() - Method in class alluxio.proto.shared.Acl.AclEntry
-
optional .alluxio.proto.shared.AclEntryType type = 1;
- getType() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
-
optional .alluxio.proto.shared.AclEntryType type = 1;
- getType() - Method in class alluxio.security.authorization.AclEntry
-
- getType() - Method in class alluxio.stress.cli.Benchmark.ProfileInput
-
- getType() - Method in class alluxio.worker.http.ResponseFileInfo
-
Get the file type.
- getTypeBytes() - Method in class alluxio.grpc.JobDescription.Builder
-
required string type = 1;
- getTypeBytes() - Method in class alluxio.grpc.JobDescription
-
required string type = 1;
- getTypeBytes() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
-
required string type = 1;
- getTypeBytes() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string type = 3;
- getTypeBytes() - Method in class alluxio.grpc.table.FieldSchema
-
optional string type = 3;
- getTypeBytes() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional string type = 3;
- getUdbConnectionUri() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_connection_uri = 2;
- getUdbConnectionUri() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string udb_connection_uri = 2;
- getUdbConnectionUri() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string udb_connection_uri = 2;
- getUdbConnectionUriBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_connection_uri = 2;
- getUdbConnectionUriBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string udb_connection_uri = 2;
- getUdbConnectionUriBytes() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string udb_connection_uri = 2;
- getUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_db_name = 3;
- getUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string udb_db_name = 3;
- getUdbDbName() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string udb_db_name = 3;
- getUdbDbNameBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_db_name = 3;
- getUdbDbNameBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string udb_db_name = 3;
- getUdbDbNameBytes() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string udb_db_name = 3;
- getUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_type = 1;
- getUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string udb_type = 1;
- getUdbType() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string udb_type = 1;
- getUdbTypeBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_type = 1;
- getUdbTypeBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string udb_type = 1;
- getUdbTypeBytes() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string udb_type = 1;
- getUfsAddress() - Method in class alluxio.client.file.options.UfsFileSystemOptions
-
- getUfsAddress() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getUfsAddress() - Method in interface alluxio.master.file.FileSystemMaster
-
- getUfsBaseFileSystem() - Method in class alluxio.client.file.DelegatingFileSystem
-
- getUfsBaseFileSystem() - Method in interface alluxio.client.file.FileSystem
-
- getUfsBaseFileSystem() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- getUfsBlockPath(UfsManager.UfsClient, long) - Static method in class alluxio.worker.BlockUtils
-
For a given block ID, derives the corresponding UFS file of this block if it falls back to
be stored in UFS.
- getUfsCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 ufsCapacityBytes = 3 [default = -1];
- getUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo
-
optional int64 ufsCapacityBytes = 3 [default = -1];
- getUfsCapacityBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional int64 ufsCapacityBytes = 3 [default = -1];
- getUfsCapacityBytes() - Method in class alluxio.util.webui.UIMountPointInfo
-
Gets ufs capacity bytes.
- getUfsCapacityBytes() - Method in class alluxio.wire.MountPointInfo
-
- getUfsClient(long) - Method in class alluxio.master.file.meta.MountTable
-
Get the associated ufs client with the mount id.
- getUfsClient() - Method in class alluxio.master.file.meta.MountTable.Resolution
-
- getUfsContentHash() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
-
- getUfsContentHash() - Method in interface alluxio.client.block.stream.DataWriter
-
- getUfsContentHash() - Method in class alluxio.client.block.stream.GrpcDataWriter
-
- getUfsContentHash() - Method in class alluxio.client.block.stream.NettyDataWriter
-
- getUfsContentHash() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
-
- getUfsFileStatus() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- getUfsFileStatus() - Method in class alluxio.grpc.UfsStatus
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- getUfsFileStatus() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- getUfsFileStatusBuilder() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- getUfsFileStatusOrBuilder() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- getUfsFileStatusOrBuilder() - Method in class alluxio.grpc.UfsStatus
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- getUfsFileStatusOrBuilder() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- getUfsFileSystemOptions() - Method in class alluxio.client.file.options.FileSystemOptions.Builder
-
- getUfsFileSystemOptions() - Method in class alluxio.client.file.options.FileSystemOptions
-
- getUfsFingerprint() - Method in class alluxio.client.file.URIStatus
-
- getUfsFingerprint() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsFingerprint = 26;
- getUfsFingerprint() - Method in class alluxio.grpc.FileInfo
-
optional string ufsFingerprint = 26;
- getUfsFingerprint() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string ufsFingerprint = 26;
- getUfsFingerprint() - Method in class alluxio.master.file.contexts.SetAttributeContext
-
- getUfsFingerprint() - Method in class alluxio.master.file.meta.Inode
-
- getUfsFingerprint() - Method in interface alluxio.master.file.meta.InodeView
-
- getUfsFingerprint() - Method in class alluxio.master.file.meta.MutableInode
-
- getUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional string ufs_fingerprint = 5;
- getUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
optional string ufs_fingerprint = 5;
- getUfsFingerprint() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
optional string ufs_fingerprint = 5;
- getUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string ufs_fingerprint = 18;
- getUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string ufs_fingerprint = 18;
- getUfsFingerprint() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string ufs_fingerprint = 18;
- getUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string ufs_fingerprint = 10;
- getUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string ufs_fingerprint = 10;
- getUfsFingerprint() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string ufs_fingerprint = 10;
- getUfsFingerprint() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string ufs_fingerprint = 15;
- getUfsFingerprint() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string ufs_fingerprint = 15;
- getUfsFingerprint() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string ufs_fingerprint = 15;
- getUfsFingerprint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string ufs_fingerprint = 11;
- getUfsFingerprint() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string ufs_fingerprint = 11;
- getUfsFingerprint() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string ufs_fingerprint = 11;
- getUfsFingerprint() - Method in class alluxio.wire.FileInfo
-
- getUfsFingerprintBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsFingerprint = 26;
- getUfsFingerprintBytes() - Method in class alluxio.grpc.FileInfo
-
optional string ufsFingerprint = 26;
- getUfsFingerprintBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string ufsFingerprint = 26;
- getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional string ufs_fingerprint = 5;
- getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
optional string ufs_fingerprint = 5;
- getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
optional string ufs_fingerprint = 5;
- getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string ufs_fingerprint = 18;
- getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string ufs_fingerprint = 18;
- getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string ufs_fingerprint = 18;
- getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string ufs_fingerprint = 10;
- getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string ufs_fingerprint = 10;
- getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string ufs_fingerprint = 10;
- getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string ufs_fingerprint = 15;
- getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string ufs_fingerprint = 15;
- getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string ufs_fingerprint = 15;
- getUfsFingerprintBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string ufs_fingerprint = 11;
- getUfsFingerprintBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string ufs_fingerprint = 11;
- getUfsFingerprintBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string ufs_fingerprint = 11;
- getUfsFullPath() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string ufs_full_path = 8;
- getUfsFullPath() - Method in class alluxio.grpc.UfsStatus
-
optional string ufs_full_path = 8;
- getUfsFullPath() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string ufs_full_path = 8;
- getUfsFullPath() - Method in class alluxio.underfs.UfsStatus
-
- getUfsFullPathBytes() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string ufs_full_path = 8;
- getUfsFullPathBytes() - Method in class alluxio.grpc.UfsStatus
-
optional string ufs_full_path = 8;
- getUfsFullPathBytes() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string ufs_full_path = 8;
- getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in interface alluxio.grpc.FileSystemMasterJobServiceGrpc.AsyncService
-
Returns the UFS information for the given mount point identified by its id.
- getUfsInfo(GetUfsInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceBlockingStub
-
Returns the UFS information for the given mount point identified by its id.
- getUfsInfo(GetUfsInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceFutureStub
-
Returns the UFS information for the given mount point identified by its id.
- getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceStub
-
Returns the UFS information for the given mount point identified by its id.
- getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in interface alluxio.grpc.FileSystemMasterWorkerServiceGrpc.AsyncService
-
Returns the UFS information for the given mount point identified by its id.
- getUfsInfo(GetUfsInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub
-
Returns the UFS information for the given mount point identified by its id.
- getUfsInfo(GetUfsInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub
-
Returns the UFS information for the given mount point identified by its id.
- getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub
-
Returns the UFS information for the given mount point identified by its id.
- getUfsInfo() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- getUfsInfo() - Method in class alluxio.grpc.GetUfsInfoPResponse
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- getUfsInfo() - Method in interface alluxio.grpc.GetUfsInfoPResponseOrBuilder
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- getUfsInfo(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getUfsInfo(long) - Method in interface alluxio.master.file.FileSystemMaster
-
- getUfsInfo(long) - Method in class alluxio.master.file.FileSystemMasterClient
-
- getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in class alluxio.master.file.FileSystemMasterJobServiceHandler
-
- getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
-
- getUfsInfo(long) - Method in class alluxio.worker.file.FileSystemMasterClient
-
- getUfsInfoBuilder() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- getUfsInfoOrBuilder() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- getUfsInfoOrBuilder() - Method in class alluxio.grpc.GetUfsInfoPResponse
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- getUfsInfoOrBuilder() - Method in interface alluxio.grpc.GetUfsInfoPResponseOrBuilder
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- GetUfsInfoPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetUfsInfoPOptions
- GetUfsInfoPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetUfsInfoPOptions
- GetUfsInfoPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetUfsInfoPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetUfsInfoPRequest
- GetUfsInfoPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetUfsInfoPRequest
- GetUfsInfoPRequestOrBuilder - Interface in alluxio.grpc
-
- GetUfsInfoPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetUfsInfoPResponse
- GetUfsInfoPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.GetUfsInfoPResponse
- GetUfsInfoPResponseOrBuilder - Interface in alluxio.grpc
-
- getUfsInstance(String) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getUfsLength() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional int64 ufsLength = 1;
- getUfsLength() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional int64 ufsLength = 1;
- getUfsLength() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional int64 ufsLength = 1;
- getUfsLocations(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocations(int) - Method in class alluxio.grpc.FileBlockInfo
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocations(int) - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocations() - Method in class alluxio.wire.FileBlockInfo
-
- getUfsLocationsBuilder(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsBuilderList() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsCount() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsCount() - Method in class alluxio.grpc.FileBlockInfo
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsCount() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsList() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsList() - Method in class alluxio.grpc.FileBlockInfo
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsList() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsOrBuilder(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsOrBuilder(int) - Method in class alluxio.grpc.FileBlockInfo
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsOrBuilder(int) - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsOrBuilderList() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsOrBuilderList() - Method in class alluxio.grpc.FileBlockInfo
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsLocationsOrBuilderList() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- getUfsManager() - Method in class alluxio.job.JobServerContext
-
- getUfsManager() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getUfsManager() - Method in class alluxio.master.MasterContext
-
- getUfsManager() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getUfsManager() - Method in interface alluxio.worker.WorkerProcess
-
- getUfsMode() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
- getUfsMode() - Method in class alluxio.grpc.UpdateUfsModePOptions
-
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
- getUfsMode() - Method in interface alluxio.grpc.UpdateUfsModePOptionsOrBuilder
-
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
- getUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
- getUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
- getUfsMode() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
-
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
- getUfsMountPointUri() - Method in class alluxio.master.file.meta.MountTable.Resolution
-
- getUfsMountPointUri() - Method in class alluxio.underfs.UfsManager.UfsClient
-
- getUfsOps() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets ufs ops.
- getUfsOpsSaved() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets ufs ops saved.
- getUfsOpsSavedCounter(AlluxioURI, DefaultFileSystemMaster.Metrics.UFSOps) - Static method in class alluxio.master.file.DefaultFileSystemMaster.Metrics
-
Get operations saved per ufs counter.
- getUfsPath() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getUfsPath() - Method in class alluxio.client.file.URIStatus
-
- getUfsPath() - Method in class alluxio.grpc.Block.Builder
-
optional string ufs_path = 3;
- getUfsPath() - Method in class alluxio.grpc.Block
-
optional string ufs_path = 3;
- getUfsPath() - Method in interface alluxio.grpc.BlockOrBuilder
-
optional string ufs_path = 3;
- getUfsPath() - Method in class alluxio.grpc.File.Builder
-
optional string ufs_path = 2;
- getUfsPath() - Method in class alluxio.grpc.File
-
optional string ufs_path = 2;
- getUfsPath() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsPath = 4;
- getUfsPath() - Method in class alluxio.grpc.FileInfo
-
optional string ufsPath = 4;
- getUfsPath() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string ufsPath = 4;
- getUfsPath() - Method in interface alluxio.grpc.FileOrBuilder
-
optional string ufs_path = 2;
- getUfsPath() - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of the under file system
- getUfsPath() - Method in class alluxio.grpc.MountPRequest
-
the path of the under file system
- getUfsPath() - Method in interface alluxio.grpc.MountPRequestOrBuilder
-
the path of the under file system
- getUfsPath() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
the ufs path
- getUfsPath() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
the ufs path
- getUfsPath() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
-
the ufs path
- getUfsPath() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
-
- getUfsPath() - Method in class alluxio.job.plan.persist.PersistConfig
-
- getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string ufs_path = 1;
- getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional string ufs_path = 1;
- getUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional string ufs_path = 1;
- getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional string ufs_path = 1;
- getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
optional string ufs_path = 1;
- getUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
optional string ufs_path = 1;
- getUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string ufs_path = 2;
- getUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional string ufs_path = 2;
- getUfsPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional string ufs_path = 2;
- getUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
optional string ufsPath = 1;
- getUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
optional string ufsPath = 1;
- getUfsPath() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
-
optional string ufsPath = 1;
- getUfsPath() - Method in class alluxio.wire.FileInfo
-
- getUfsPath() - Method in class alluxio.worker.grpc.UfsFileWriteRequest
-
- getUfsPath() - Method in class alluxio.worker.netty.UfsFileWriteRequest
-
- getUfsPath(AlluxioURI) - Method in class alluxio.worker.s3.S3NettyHandler
-
Gets UFS full path from Alluxio path.
- getUfsPathBytes() - Method in class alluxio.grpc.Block.Builder
-
optional string ufs_path = 3;
- getUfsPathBytes() - Method in class alluxio.grpc.Block
-
optional string ufs_path = 3;
- getUfsPathBytes() - Method in interface alluxio.grpc.BlockOrBuilder
-
optional string ufs_path = 3;
- getUfsPathBytes() - Method in class alluxio.grpc.File.Builder
-
optional string ufs_path = 2;
- getUfsPathBytes() - Method in class alluxio.grpc.File
-
optional string ufs_path = 2;
- getUfsPathBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsPath = 4;
- getUfsPathBytes() - Method in class alluxio.grpc.FileInfo
-
optional string ufsPath = 4;
- getUfsPathBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string ufsPath = 4;
- getUfsPathBytes() - Method in interface alluxio.grpc.FileOrBuilder
-
optional string ufs_path = 2;
- getUfsPathBytes() - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of the under file system
- getUfsPathBytes() - Method in class alluxio.grpc.MountPRequest
-
the path of the under file system
- getUfsPathBytes() - Method in interface alluxio.grpc.MountPRequestOrBuilder
-
the path of the under file system
- getUfsPathBytes() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
the ufs path
- getUfsPathBytes() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
the ufs path
- getUfsPathBytes() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
-
the ufs path
- getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string ufs_path = 1;
- getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional string ufs_path = 1;
- getUfsPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional string ufs_path = 1;
- getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional string ufs_path = 1;
- getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
optional string ufs_path = 1;
- getUfsPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
optional string ufs_path = 1;
- getUfsPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string ufs_path = 2;
- getUfsPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional string ufs_path = 2;
- getUfsPathBytes() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional string ufs_path = 2;
- getUfsPathBytes() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
optional string ufsPath = 1;
- getUfsPathBytes() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
optional string ufsPath = 1;
- getUfsPathBytes() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
-
optional string ufsPath = 1;
- getUfsReadOptions() - Method in class alluxio.grpc.CopyRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptions() - Method in class alluxio.grpc.CopyRequest
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptions() - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptions() - Method in class alluxio.grpc.MoveRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptions() - Method in class alluxio.grpc.MoveRequest
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptions() - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptionsBuilder() - Method in class alluxio.grpc.CopyRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptionsBuilder() - Method in class alluxio.grpc.MoveRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptionsOrBuilder() - Method in class alluxio.grpc.CopyRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptionsOrBuilder() - Method in class alluxio.grpc.CopyRequest
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptionsOrBuilder() - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptionsOrBuilder() - Method in class alluxio.grpc.MoveRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptionsOrBuilder() - Method in class alluxio.grpc.MoveRequest
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadOptionsOrBuilder() - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- getUfsReadSize() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets ufs read size.
- getUfsReadWorkerLocation() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- getUfsReadWorkerLocation() - Method in class alluxio.grpc.OpenFilePOptions
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- getUfsReadWorkerLocation() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- getUfsReadWorkerLocationBuilder() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- getUfsReadWorkerLocationOrBuilder() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- getUfsReadWorkerLocationOrBuilder() - Method in class alluxio.grpc.OpenFilePOptions
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- getUfsReadWorkerLocationOrBuilder() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- getUfsResource() - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
-
- getUfsStatus() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatus() - Method in class alluxio.grpc.LoadFileFailure
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatus() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatus(int) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatus(int) - Method in class alluxio.grpc.LoadFileRequest
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatus(int) - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatus() - Method in class alluxio.master.file.contexts.CompleteFileContext
-
- getUfsStatus() - Method in class alluxio.master.file.contexts.CreateDirectoryContext
-
- getUfsStatus() - Method in class alluxio.master.file.contexts.LoadMetadataContext
-
- getUfsStatusBuilder() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusBuilder(int) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusBuilderList() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusCount() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusCount() - Method in class alluxio.grpc.LoadFileRequest
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusCount() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusList() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusList() - Method in class alluxio.grpc.LoadFileRequest
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusList() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusOrBuilder() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusOrBuilder() - Method in class alluxio.grpc.LoadFileFailure
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusOrBuilder() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusOrBuilder(int) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusOrBuilder(int) - Method in class alluxio.grpc.LoadFileRequest
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusOrBuilder(int) - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusOrBuilderList() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusOrBuilderList() - Method in class alluxio.grpc.LoadFileRequest
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStatusOrBuilderList() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- getUfsStringLocations(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
repeated string ufsStringLocations = 4;
- getUfsStringLocations(int) - Method in class alluxio.grpc.FileBlockInfo
-
repeated string ufsStringLocations = 4;
- getUfsStringLocations(int) - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
repeated string ufsStringLocations = 4;
- getUfsStringLocationsBytes(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
repeated string ufsStringLocations = 4;
- getUfsStringLocationsBytes(int) - Method in class alluxio.grpc.FileBlockInfo
-
repeated string ufsStringLocations = 4;
- getUfsStringLocationsBytes(int) - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
repeated string ufsStringLocations = 4;
- getUfsStringLocationsCount() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
repeated string ufsStringLocations = 4;
- getUfsStringLocationsCount() - Method in class alluxio.grpc.FileBlockInfo
-
repeated string ufsStringLocations = 4;
- getUfsStringLocationsCount() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
repeated string ufsStringLocations = 4;
- getUfsStringLocationsList() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
repeated string ufsStringLocations = 4;
- getUfsStringLocationsList() - Method in class alluxio.grpc.FileBlockInfo
-
repeated string ufsStringLocations = 4;
- getUfsStringLocationsList() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
repeated string ufsStringLocations = 4;
- getUfsSyncMetric(long) - Method in class alluxio.master.file.meta.MountTable
-
- getUfsSyncPathCache() - Method in class alluxio.master.file.meta.MountTable
-
- getUfsType() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsType = 35;
- getUfsType() - Method in class alluxio.grpc.FileInfo
-
optional string ufsType = 35;
- getUfsType() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string ufsType = 35;
- getUfsType() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsType = 2;
- getUfsType() - Method in class alluxio.grpc.MountPointInfo
-
optional string ufsType = 2;
- getUfsType() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional string ufsType = 2;
- getUfsType() - Method in class alluxio.util.webui.UIMountPointInfo
-
Gets ufs type.
- getUfsType() - Method in class alluxio.wire.FileInfo
-
- getUfsType() - Method in class alluxio.wire.MountPointInfo
-
- getUfsTypeBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsType = 35;
- getUfsTypeBytes() - Method in class alluxio.grpc.FileInfo
-
optional string ufsType = 35;
- getUfsTypeBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string ufsType = 35;
- getUfsTypeBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsType = 2;
- getUfsTypeBytes() - Method in class alluxio.grpc.MountPointInfo
-
optional string ufsType = 2;
- getUfsTypeBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional string ufsType = 2;
- getUfsUri() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
required string ufsUri = 1;
- getUfsUri() - Method in class alluxio.grpc.GetMountIdPRequest
-
required string ufsUri = 1;
- getUfsUri() - Method in interface alluxio.grpc.GetMountIdPRequestOrBuilder
-
required string ufsUri = 1;
- getUfsUri() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsUri = 1;
- getUfsUri() - Method in class alluxio.grpc.MountPointInfo
-
optional string ufsUri = 1;
- getUfsUri() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional string ufsUri = 1;
- getUfsUri() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
optional string ufsUri = 1;
- getUfsUri() - Method in class alluxio.grpc.ReverseResolvePRequest
-
optional string ufsUri = 1;
- getUfsUri() - Method in interface alluxio.grpc.ReverseResolvePRequestOrBuilder
-
optional string ufsUri = 1;
- getUfsUri() - Method in class alluxio.master.file.meta.options.MountInfo
-
- getUfsUri() - Method in class alluxio.util.webui.UIMountPointInfo
-
Gets ufs uri.
- getUfsUri() - Method in class alluxio.wire.MountPointInfo
-
- getUfsUriBytes() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
required string ufsUri = 1;
- getUfsUriBytes() - Method in class alluxio.grpc.GetMountIdPRequest
-
required string ufsUri = 1;
- getUfsUriBytes() - Method in interface alluxio.grpc.GetMountIdPRequestOrBuilder
-
required string ufsUri = 1;
- getUfsUriBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsUri = 1;
- getUfsUriBytes() - Method in class alluxio.grpc.MountPointInfo
-
optional string ufsUri = 1;
- getUfsUriBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional string ufsUri = 1;
- getUfsUriBytes() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
optional string ufsUri = 1;
- getUfsUriBytes() - Method in class alluxio.grpc.ReverseResolvePRequest
-
optional string ufsUri = 1;
- getUfsUriBytes() - Method in interface alluxio.grpc.ReverseResolvePRequestOrBuilder
-
optional string ufsUri = 1;
- getUfsUsedBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 ufsUsedBytes = 4 [default = -1];
- getUfsUsedBytes() - Method in class alluxio.grpc.MountPointInfo
-
optional int64 ufsUsedBytes = 4 [default = -1];
- getUfsUsedBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional int64 ufsUsedBytes = 4 [default = -1];
- getUfsUsedBytes() - Method in class alluxio.util.webui.UIMountPointInfo
-
Gets ufs used bytes.
- getUfsUsedBytes() - Method in class alluxio.wire.MountPointInfo
-
- getUfsWriteSize() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets ufs write size.
- getUid(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Retrieves the uid of the given user.
- getUid() - Method in interface alluxio.fuse.auth.AuthPolicy
-
- getUid(String) - Method in interface alluxio.fuse.auth.AuthPolicy
-
Gets the uid based on the auth policy and file owner.
- getUid() - Method in class alluxio.fuse.auth.CustomAuthPolicy
-
- getUid() - Method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
-
- getUid() - Method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
-
- getUid(String) - Method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
-
- getUid() - Method in class alluxio.fuse.file.CreateFileStatus
-
- getUMask(String) - Static method in class alluxio.util.ModeUtils
-
Gets the file / directory creation umask.
- getUncaughtExceptionHandler() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns the handler for internal worker threads that terminate due to unrecoverable errors
encountered while executing tasks.
- getUnchecked() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool unchecked = 3;
- getUnchecked() - Method in class alluxio.grpc.DeletePOptions
-
optional bool unchecked = 3;
- getUnchecked() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional bool unchecked = 3;
- getUnderFileSystem() - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
This is only used in the test.
- getUnderFileSystem(String) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getUnderFileSystem() - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
-
- getUnderFSType() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- getUnderFSType() - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.adl.AdlUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.cosn.CosnUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.ozone.OzoneUnderFileSystem
-
- getUnderFSType() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- getUnderFSType() - Method in interface alluxio.underfs.UnderFileSystem
-
Returns the name of the under filesystem implementation.
- getUnderFSType() - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getUnderFSType() - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
-
- getUnderlyingFileSystem() - Method in class alluxio.client.file.DelegatingFileSystem
-
- getUnderlyingJournalContext() - Method in class alluxio.master.journal.FileSystemMergeJournalContext
-
- getUnderStorageType() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getUnderStorageType() - Method in enum alluxio.client.WriteType
-
- getUnfinishedTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 unfinishedTasks = 7;
- getUnfinishedTasks() - Method in class alluxio.grpc.JobWorkerHealth
-
optional int32 unfinishedTasks = 7;
- getUnfinishedTasks() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional int32 unfinishedTasks = 7;
- getUnfinishedTasks() - Method in class alluxio.job.wire.JobWorkerHealth
-
- getUniqueBlockCount() - Method in interface alluxio.master.block.BlockMaster
-
- getUniqueBlockCount() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getUniqueBlockCount() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets unique block count.
- getUnixGroups(String) - Static method in class alluxio.util.CommonUtils
-
Gets the current user's group list from Unix by running the command 'groups' NOTE.
- getUnixMountInfo() - Static method in class alluxio.util.ShellUtils
-
Gets system mount information.
- getUnknownFields() - Method in class alluxio.grpc.ActionInfo
-
- getUnknownFields() - Method in class alluxio.grpc.AddPolicyPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.AddPolicyPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.AddPolicyPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.AddQuorumServerRequest
-
- getUnknownFields() - Method in class alluxio.grpc.AsyncCacheRequest
-
- getUnknownFields() - Method in class alluxio.grpc.AsyncCacheResponse
-
- getUnknownFields() - Method in class alluxio.grpc.BackupPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.BackupPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.BackupPStatus
-
- getUnknownFields() - Method in class alluxio.grpc.BackupStatusPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.Block
-
- getUnknownFields() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.BlockHeartbeatPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.BlockIdList
-
- getUnknownFields() - Method in class alluxio.grpc.BlockInfo
-
- getUnknownFields() - Method in class alluxio.grpc.BlockLocation
-
- getUnknownFields() - Method in class alluxio.grpc.BlockMasterInfo
-
- getUnknownFields() - Method in class alluxio.grpc.BlockStatus
-
- getUnknownFields() - Method in class alluxio.grpc.BlockStoreLocationProto
-
- getUnknownFields() - Method in class alluxio.grpc.BuildVersion
-
- getUnknownFields() - Method in class alluxio.grpc.CacheRequest
-
- getUnknownFields() - Method in class alluxio.grpc.CacheResponse
-
- getUnknownFields() - Method in class alluxio.grpc.CancelPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.CancelPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.CancelPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.CancelTaskCommand
-
- getUnknownFields() - Method in class alluxio.grpc.CheckAccessPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.CheckAccessPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.CheckAccessPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.CheckConsistencyPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.CheckpointPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.CheckpointPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.CheckRequest
-
- getUnknownFields() - Method in class alluxio.grpc.CheckResponse
-
- getUnknownFields() - Method in class alluxio.grpc.Chunk
-
- getUnknownFields() - Method in class alluxio.grpc.ClearMetricsPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ClearMetricsPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.ClearMetricsRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ClearMetricsResponse
-
- getUnknownFields() - Method in class alluxio.grpc.ClientMetrics
-
- getUnknownFields() - Method in class alluxio.grpc.CmdProgress
-
- getUnknownFields() - Method in class alluxio.grpc.CmdStatusBlock
-
- getUnknownFields() - Method in class alluxio.grpc.CmdSummary
-
- getUnknownFields() - Method in class alluxio.grpc.Command
-
- getUnknownFields() - Method in class alluxio.grpc.CommitBlockPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.CommitBlockPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.CommitBlockPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.CompleteFilePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.CompleteFilePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.CompleteFilePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.ConfigCheckReport
-
- getUnknownFields() - Method in class alluxio.grpc.ConfigProperties
-
- getUnknownFields() - Method in class alluxio.grpc.ConfigProperty
-
- getUnknownFields() - Method in class alluxio.grpc.CopyJobPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.CopyRequest
-
- getUnknownFields() - Method in class alluxio.grpc.CopyResponse
-
- getUnknownFields() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.CreateDirectoryPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.CreateFilePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.CreateFilePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.CreateFilePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.DecommissionWorkerPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.DeletePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.DeletePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.DeletePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.DownloadSnapshotPRequest
-
Deprecated.
- getUnknownFields() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
Deprecated.
- getUnknownFields() - Method in class alluxio.grpc.ErrorInfo
-
- getUnknownFields() - Method in class alluxio.grpc.ExistsPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.ExistsPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ExistsPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.File
-
- getUnknownFields() - Method in class alluxio.grpc.FileBlockInfo
-
- getUnknownFields() - Method in class alluxio.grpc.FileFailure
-
- getUnknownFields() - Method in class alluxio.grpc.FileInfo
-
- getUnknownFields() - Method in class alluxio.grpc.FileSystemCommand
-
- getUnknownFields() - Method in class alluxio.grpc.FileSystemCommandOptions
-
- getUnknownFields() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.FreePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.FreePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.FreePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.FreeWorkerRequest
-
- getUnknownFields() - Method in class alluxio.grpc.FreeWorkerResponse
-
- getUnknownFields() - Method in class alluxio.grpc.FsOpPId
-
- getUnknownFields() - Method in class alluxio.grpc.GetActionInfoOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetActionInfoRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetActionInfoResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetBlockInfoPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetBlockInfoPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetBlockInfoPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetCapacityBytesPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetCapacityBytesPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetConfigHashPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetConfigHashPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetConfigReportPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetConfigReportPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetConfigurationPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetConfigurationPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetFileInfoPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetFileInfoPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetFileInfoPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetFilePathPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetFilePathPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobMasterIdPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobMasterIdPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobProgressPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobProgressPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobStatusPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobStatusPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetJobStatusPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetMasterIdPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetMasterIdPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetMasterIdPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetMasterInfoPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetMasterInfoPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetMetricsPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetMetricsPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetMountIdPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetMountIdPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetMountTablePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetMountTablePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetNodeStatePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetNodeStatePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetPolicyStatusPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetPolicyStatusPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetQuorumInfoPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetQuorumInfoPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetRegisterLeasePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetRegisterLeasePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetServiceVersionPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetServiceVersionPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- getUnknownFields() - Method in class alluxio.grpc.GetSnapshotInfoResponse
-
Deprecated.
- getUnknownFields() - Method in class alluxio.grpc.GetSnapshotRequest
-
Deprecated.
- getUnknownFields() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetStatusPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetStatusPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetStatusPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetUfsInfoPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetUfsInfoPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetUfsInfoPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetUsedBytesPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetUsedBytesPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetWorkerIdPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.GetWorkerIdPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.InconsistentProperties
-
- getUnknownFields() - Method in class alluxio.grpc.InconsistentProperty
-
- getUnknownFields() - Method in class alluxio.grpc.InconsistentPropertyValues
-
- getUnknownFields() - Method in class alluxio.grpc.JobCommand
-
- getUnknownFields() - Method in class alluxio.grpc.JobDescription
-
- getUnknownFields() - Method in class alluxio.grpc.JobHeartbeatPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.JobInfo
-
- getUnknownFields() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.JobMasterStatus
-
- getUnknownFields() - Method in class alluxio.grpc.JobProgress
-
- getUnknownFields() - Method in class alluxio.grpc.JobProgressPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.JobServiceSummary
-
- getUnknownFields() - Method in class alluxio.grpc.JobStatusBlock
-
- getUnknownFields() - Method in class alluxio.grpc.JobUnused
-
- getUnknownFields() - Method in class alluxio.grpc.JobWorkerHealth
-
- getUnknownFields() - Method in class alluxio.grpc.JournalQueryRequest
-
- getUnknownFields() - Method in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- getUnknownFields() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ListAllPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.ListAllPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ListAllPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.ListPolicyPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.ListPolicyPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ListPolicyPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.ListProxyStatusPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.ListProxyStatusPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ListProxyStatusPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.ListStatusPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.ListStatusPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ListStatusPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.LoadFileFailure
-
- getUnknownFields() - Method in class alluxio.grpc.LoadFileRequest
-
- getUnknownFields() - Method in class alluxio.grpc.LoadFileResponse
-
- getUnknownFields() - Method in class alluxio.grpc.LoadJobPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.LoadMetadataPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.LoadRequest
-
- getUnknownFields() - Method in class alluxio.grpc.LoadResponse
-
- getUnknownFields() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
- getUnknownFields() - Method in class alluxio.grpc.MasterHeartbeatPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.MasterHeartbeatPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.MasterHeartbeatPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.MasterInfo
-
- getUnknownFields() - Method in class alluxio.grpc.MasterVersion
-
- getUnknownFields() - Method in class alluxio.grpc.MessagingRequestHeader
-
- getUnknownFields() - Method in class alluxio.grpc.MessagingResponseHeader
-
- getUnknownFields() - Method in class alluxio.grpc.Metric
-
- getUnknownFields() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.MetricValue
-
- getUnknownFields() - Method in class alluxio.grpc.MountPointInfo
-
- getUnknownFields() - Method in class alluxio.grpc.MountPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.MountPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.MountPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.MoveBlockRequest
-
- getUnknownFields() - Method in class alluxio.grpc.MoveBlockResponse
-
- getUnknownFields() - Method in class alluxio.grpc.MoveJobPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.MoveRequest
-
- getUnknownFields() - Method in class alluxio.grpc.MoveResponse
-
- getUnknownFields() - Method in class alluxio.grpc.NeedsSyncRequest
-
- getUnknownFields() - Method in class alluxio.grpc.NeedsSyncResponse
-
- getUnknownFields() - Method in class alluxio.grpc.NetAddress
-
- getUnknownFields() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.OpenFilePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.PAcl
-
- getUnknownFields() - Method in class alluxio.grpc.PAclEntry
-
- getUnknownFields() - Method in class alluxio.grpc.PersistCommandOptions
-
- getUnknownFields() - Method in class alluxio.grpc.PersistFile
-
- getUnknownFields() - Method in class alluxio.grpc.PMode
-
- getUnknownFields() - Method in class alluxio.grpc.PolicyInfo
-
- getUnknownFields() - Method in class alluxio.grpc.PolicyStatus
-
- getUnknownFields() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.ProxyStatus
-
- getUnknownFields() - Method in class alluxio.grpc.QuorumServerInfo
-
- getUnknownFields() - Method in class alluxio.grpc.ReadRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ReadResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterCommand
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterJobMasterPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterJobMasterPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterMasterPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterMasterPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterMasterPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.RegisterWorkerPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RemoveBlockRequest
-
- getUnknownFields() - Method in class alluxio.grpc.RemoveBlockResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RemovePolicyPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.RemovePolicyPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.RemovePolicyPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RenamePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.RenamePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.RenamePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.ResetPrioritiesPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.ResetPrioritiesPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ResetPrioritiesPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RetryInfo
-
- getUnknownFields() - Method in class alluxio.grpc.ReverseResolvePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ReverseResolvePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.Route
-
- getUnknownFields() - Method in class alluxio.grpc.RouteFailure
-
- getUnknownFields() - Method in class alluxio.grpc.RunPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.RunPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.RunPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.RunTaskCommand
-
- getUnknownFields() - Method in class alluxio.grpc.S3SyntaxOptions
-
- getUnknownFields() - Method in class alluxio.grpc.SaslMessage
-
- getUnknownFields() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.SetAclPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.SetAclPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.SetAclPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.SetAttributePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.SetAttributePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.SetAttributePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.SetPathConfigurationPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.SetPathConfigurationPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
-
- getUnknownFields() - Method in class alluxio.grpc.SnapshotData
-
- getUnknownFields() - Method in class alluxio.grpc.SnapshotMetadata
-
- getUnknownFields() - Method in class alluxio.grpc.StatusSummary
-
- getUnknownFields() - Method in class alluxio.grpc.StopJobPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.StopJobPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.StorageList
-
- getUnknownFields() - Method in class alluxio.grpc.SubmitJobPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.SubmitJobPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.SubmitOptions
-
- getUnknownFields() - Method in class alluxio.grpc.SubmitRequest
-
- getUnknownFields() - Method in class alluxio.grpc.SubmitResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.AllOrNoneSet
-
- getUnknownFields() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.AttachDatabasePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
- getUnknownFields() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
- getUnknownFields() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
- getUnknownFields() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
- getUnknownFields() - Method in class alluxio.grpc.table.ColumnStatisticsList
-
- getUnknownFields() - Method in class alluxio.grpc.table.Constraint
-
- getUnknownFields() - Method in class alluxio.grpc.table.Database
-
- getUnknownFields() - Method in class alluxio.grpc.table.Date
-
- getUnknownFields() - Method in class alluxio.grpc.table.DateColumnStatsData
-
- getUnknownFields() - Method in class alluxio.grpc.table.Decimal
-
- getUnknownFields() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
- getUnknownFields() - Method in class alluxio.grpc.table.DetachDatabasePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.DetachDatabasePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.Domain
-
- getUnknownFields() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
- getUnknownFields() - Method in class alluxio.grpc.table.EquatableValueSet
-
- getUnknownFields() - Method in class alluxio.grpc.table.FieldSchema
-
- getUnknownFields() - Method in class alluxio.grpc.table.FileStatistics
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetAllTablesPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetAllTablesPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetDatabasePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetDatabasePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetTablePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetTablePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.Layout
-
- getUnknownFields() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
- getUnknownFields() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
- getUnknownFields() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
-
- getUnknownFields() - Method in class alluxio.grpc.table.layout.hive.Storage
-
- getUnknownFields() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
- getUnknownFields() - Method in class alluxio.grpc.table.LayoutSpec
-
- getUnknownFields() - Method in class alluxio.grpc.table.LongColumnStatsData
-
- getUnknownFields() - Method in class alluxio.grpc.table.Partition
-
- getUnknownFields() - Method in class alluxio.grpc.table.PartitionSpec
-
- getUnknownFields() - Method in class alluxio.grpc.table.Range
-
- getUnknownFields() - Method in class alluxio.grpc.table.RangeSet
-
- getUnknownFields() - Method in class alluxio.grpc.table.ReadTablePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.ReadTablePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.Schema
-
- getUnknownFields() - Method in class alluxio.grpc.table.StringColumnStatsData
-
- getUnknownFields() - Method in class alluxio.grpc.table.SyncDatabasePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.SyncDatabasePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.SyncStatus
-
- getUnknownFields() - Method in class alluxio.grpc.table.TableInfo
-
- getUnknownFields() - Method in class alluxio.grpc.table.Transformation
-
- getUnknownFields() - Method in class alluxio.grpc.table.TransformJobInfo
-
- getUnknownFields() - Method in class alluxio.grpc.table.TransformTablePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.table.TransformTablePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.table.Value
-
- getUnknownFields() - Method in class alluxio.grpc.TierList
-
- getUnknownFields() - Method in class alluxio.grpc.TransferLeaderMessage
-
- getUnknownFields() - Method in class alluxio.grpc.TransferLeadershipPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.TransferLeadershipPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.TransportMessage
-
- getUnknownFields() - Method in class alluxio.grpc.TriggerPolicyRequest
-
- getUnknownFields() - Method in class alluxio.grpc.TriggerPolicyResponse
-
- getUnknownFields() - Method in class alluxio.grpc.UfsFileStatus
-
- getUnknownFields() - Method in class alluxio.grpc.UfsInfo
-
- getUnknownFields() - Method in class alluxio.grpc.UfsReadOptions
-
- getUnknownFields() - Method in class alluxio.grpc.UfsStatus
-
- getUnknownFields() - Method in class alluxio.grpc.UnmountPOptions
-
- getUnknownFields() - Method in class alluxio.grpc.UnmountPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.UnmountPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.UpdateMountPRequest
-
- getUnknownFields() - Method in class alluxio.grpc.UpdateMountPResponse
-
- getUnknownFields() - Method in class alluxio.grpc.UpdateUfsModePOptions
-
- getUnknownFields() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
- getUnknownFields() - Method in class alluxio.grpc.UpdateUfsModePResponse
-
- getUnknownFields() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
Deprecated.
- getUnknownFields() - Method in class alluxio.grpc.UploadSnapshotPResponse
-
Deprecated.
- getUnknownFields() - Method in class alluxio.grpc.WorkerIdentity
-
- getUnknownFields() - Method in class alluxio.grpc.WorkerInfo
-
- getUnknownFields() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
- getUnknownFields() - Method in class alluxio.grpc.WorkerNetAddress
-
- getUnknownFields() - Method in class alluxio.grpc.WriteOptions
-
- getUnknownFields() - Method in class alluxio.grpc.WriteRequest
-
- getUnknownFields() - Method in class alluxio.grpc.WriteRequestCommand
-
- getUnknownFields() - Method in class alluxio.grpc.WriteResponse
-
- getUnknownFields() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
- getUnknownFields() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.Response
-
- getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
- getUnknownFields() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.NewBlockEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.RenameEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.SetAclEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.StringPairEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Job.FileFilter
-
- getUnknownFields() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Journal.JournalOpPId
-
- getUnknownFields() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
- getUnknownFields() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
-
- getUnknownFields() - Method in class alluxio.proto.meta.Block.BlockLocation
-
- getUnknownFields() - Method in class alluxio.proto.meta.Block.BlockMeta
-
- getUnknownFields() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
-
- getUnknownFields() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
- getUnknownFields() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
- getUnknownFields() - Method in class alluxio.proto.shared.Acl.AclActions
-
- getUnknownFields() - Method in class alluxio.proto.shared.Acl.AclEntry
-
- getUnknownFields() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
- getUnmodifiableView() - Method in class alluxio.master.file.state.DirectoryId
-
- getUnmountMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getUnrecognizedOptions() - Method in class alluxio.fuse.options.MountOptions
-
Gets options that are neither an Alluxio property, nor an option special to Alluxio Fuse.
- getUnscaled() - Method in class alluxio.grpc.table.Decimal.Builder
-
required bytes unscaled = 2;
- getUnscaled() - Method in class alluxio.grpc.table.Decimal
-
required bytes unscaled = 2;
- getUnscaled() - Method in interface alluxio.grpc.table.DecimalOrBuilder
-
required bytes unscaled = 2;
- getUnused0(int) - Method in class alluxio.grpc.JobInfo.Builder
-
Around for backwards compatibility
- getUnused0(int) - Method in class alluxio.grpc.JobInfo
-
Around for backwards compatibility
- getUnused0(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
-
Around for backwards compatibility
- getUnused0Builder(int) - Method in class alluxio.grpc.JobInfo.Builder
-
Around for backwards compatibility
- getUnused0BuilderList() - Method in class alluxio.grpc.JobInfo.Builder
-
Around for backwards compatibility
- getUnused0Count() - Method in class alluxio.grpc.JobInfo.Builder
-
Around for backwards compatibility
- getUnused0Count() - Method in class alluxio.grpc.JobInfo
-
Around for backwards compatibility
- getUnused0Count() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
Around for backwards compatibility
- getUnused0List() - Method in class alluxio.grpc.JobInfo.Builder
-
Around for backwards compatibility
- getUnused0List() - Method in class alluxio.grpc.JobInfo
-
Around for backwards compatibility
- getUnused0List() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
Around for backwards compatibility
- getUnused0OrBuilder(int) - Method in class alluxio.grpc.JobInfo.Builder
-
Around for backwards compatibility
- getUnused0OrBuilder(int) - Method in class alluxio.grpc.JobInfo
-
Around for backwards compatibility
- getUnused0OrBuilder(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
-
Around for backwards compatibility
- getUnused0OrBuilderList() - Method in class alluxio.grpc.JobInfo.Builder
-
Around for backwards compatibility
- getUnused0OrBuilderList() - Method in class alluxio.grpc.JobInfo
-
Around for backwards compatibility
- getUnused0OrBuilderList() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
Around for backwards compatibility
- getUnused1() - Method in class alluxio.grpc.JobInfo.Builder
-
formerly result
- getUnused1() - Method in class alluxio.grpc.JobInfo
-
formerly result
- getUnused1() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
formerly result
- getUnused1Bytes() - Method in class alluxio.grpc.JobInfo.Builder
-
formerly result
- getUnused1Bytes() - Method in class alluxio.grpc.JobInfo
-
formerly result
- getUnused1Bytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
formerly result
- getUpdateCheck() - Method in class alluxio.fuse.options.FuseCliOptions
-
- getUpdateConfigurationMethod() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
-
- getUpdateInode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- getUpdateInode() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- getUpdateInode() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- getUpdateInodeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- getUpdateInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- getUpdateInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- getUpdateInodeDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- getUpdateInodeDirectoryBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- getUpdateInodeDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- getUpdateInodeDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- getUpdateInodeDirectoryOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- getUpdateInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- getUpdateInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- getUpdateInodeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- getUpdateInodeFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- getUpdateInodeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- getUpdateInodeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- getUpdateInodeFileOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- getUpdateInodeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- getUpdateInodeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- getUpdateInodeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- getUpdateLastAccessTime() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional bool updateLastAccessTime = 4 [default = true];
- getUpdateLastAccessTime() - Method in class alluxio.grpc.OpenFilePOptions
-
optional bool updateLastAccessTime = 4 [default = true];
- getUpdateLastAccessTime() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional bool updateLastAccessTime = 4 [default = true];
- getUpdateMountMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getUpdateTimestamps() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional bool updateTimestamps = 4 [default = true];
- getUpdateTimestamps() - Method in class alluxio.grpc.GetStatusPOptions
-
optional bool updateTimestamps = 4 [default = true];
- getUpdateTimestamps() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional bool updateTimestamps = 4 [default = true];
- getUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- getUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- getUpdateUfsMode() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- getUpdateUfsModeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- getUpdateUfsModeMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- getUpdateUfsModeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- getUpdateUfsModeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- getUpdateUfsModeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- getUploadId() - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
-
- getUploadId() - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
-
- getUploadId() - Method in class alluxio.proxy.s3.ListPartsResult
-
- getUploadPath() - Method in class alluxio.underfs.s3a.S3AOutputStream
-
- getUploads() - Method in class alluxio.proxy.s3.ListMultipartUploadsResult
-
- getUploadSnapshotMethod() - Static method in class alluxio.grpc.RaftJournalServiceGrpc
-
- getUptime() - Method in class alluxio.util.webui.UIWorkerInfo
-
Gets uptime.
- getUptime() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets uptime.
- getUptimeClockTime() - Method in class alluxio.util.webui.NodeInfo
-
Gets uptime clock time.
- getUptimeDuration() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get time running.
- getUpTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int64 upTimeMs = 6;
- getUpTimeMs() - Method in class alluxio.grpc.MasterInfo
-
optional int64 upTimeMs = 6;
- getUpTimeMs() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional int64 upTimeMs = 6;
- getUptimeMs() - Method in class alluxio.master.MasterProcess
-
- getUptimeMs() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getUptimeMs() - Method in interface alluxio.master.meta.MetaMaster
-
- getUptimeMs() - Method in class alluxio.proxy.AlluxioProxyProcess
-
- getUptimeMs() - Method in interface alluxio.proxy.ProxyProcess
-
- getUptimeMs() - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- getUptimeMs() - Method in class alluxio.wire.AlluxioJobWorkerInfo
-
- getUptimeMs() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getUptimeMs() - Method in class alluxio.wire.AlluxioProxyInfo
-
- getUptimeMs() - Method in class alluxio.wire.AlluxioWorkerInfo
-
- getUptimeMs() - Method in class alluxio.worker.AlluxioJobWorkerProcess
-
- getUptimeMs() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getUptimeMs() - Method in interface alluxio.worker.JobWorkerProcess
-
- getUptimeMs() - Method in interface alluxio.worker.WorkerProcess
-
- getUri() - Method in class alluxio.grpc.UfsInfo.Builder
-
optional string uri = 1;
- getUri() - Method in class alluxio.grpc.UfsInfo
-
optional string uri = 1;
- getUri() - Method in interface alluxio.grpc.UfsInfoOrBuilder
-
optional string uri = 1;
- getUri() - Method in class alluxio.hadoop.AbstractFileSystem
-
- getUri() - Method in class alluxio.hadoop.LocalCacheFileSystem
-
- getUri() - Method in class alluxio.master.file.meta.LockedInodePath
-
- getUri() - Method in class alluxio.master.file.meta.MountTable.Resolution
-
- getUri() - Method in class alluxio.master.file.meta.MountTable.ReverseResolution
-
- getUri() - Method in class alluxio.master.file.PersistJob
-
- getUri() - Method in class alluxio.master.LocalAlluxioMaster
-
- getUri() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- getUri() - Method in class alluxio.wire.UfsInfo
-
- getUriBytes() - Method in class alluxio.grpc.UfsInfo.Builder
-
optional string uri = 1;
- getUriBytes() - Method in class alluxio.grpc.UfsInfo
-
optional string uri = 1;
- getUriBytes() - Method in interface alluxio.grpc.UfsInfoOrBuilder
-
optional string uri = 1;
- getUriStatus() - Method in class alluxio.hadoop.AlluxioFileStatus
-
get uri status.
- getUriValidationEnabled() - Method in class alluxio.client.file.FileSystemContext
-
- getUriValidationEnabled() - Method in class alluxio.ClientContext
-
- getUsage() - Method in class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
-
- getUsage() - Method in class alluxio.cli.bundler.command.CollectConfigCommand
-
- getUsage() - Method in class alluxio.cli.bundler.command.CollectEnvCommand
-
- getUsage() - Method in class alluxio.cli.bundler.command.CollectJvmInfoCommand
-
- getUsage() - Method in class alluxio.cli.bundler.command.CollectLogCommand
-
- getUsage() - Method in class alluxio.cli.bundler.command.CollectMetricsCommand
-
- getUsage() - Method in interface alluxio.cli.Command
-
- getUsage() - Method in class alluxio.cli.command.metadatacache.DropAllCommand
-
- getUsage() - Method in class alluxio.cli.command.metadatacache.DropCommand
-
- getUsage() - Method in class alluxio.cli.command.metadatacache.SizeCommand
-
- getUsage() - Method in class alluxio.cli.command.MetadataCacheCommand
-
- getUsage() - Method in class alluxio.cli.extensions.command.InstallCommand
-
- getUsage() - Method in class alluxio.cli.extensions.command.LsCommand
-
- getUsage() - Method in class alluxio.cli.extensions.command.UninstallCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.CatCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.CheckCachedCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.ChecksumCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.ChgrpCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.ChmodCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.ChownCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.CpCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.FreeCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.HeadCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.HelpCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.LoadCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.LocationCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.LsCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.MkdirCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.MvCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.RmCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.StatCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.TailCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.TestCommand
-
- getUsage() - Method in class alluxio.cli.fs.command.TouchCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.command.BackupCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.command.EnableWorkerCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.command.JournalCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.command.MetricsCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.command.NodesCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.command.ReportCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
-
- getUsage() - Method in class alluxio.cli.fsadmin.nodes.WorkerStatusCommand
-
- getUsage() - Method in interface alluxio.client.file.cache.CacheManager
-
- getUsage() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- getUsage() - Method in interface alluxio.client.file.cache.CacheStatus
-
Gets cache usage.
- getUsage() - Method in class alluxio.client.file.cache.DefaultPageMetaStore
-
- getUsage() - Method in class alluxio.client.file.cache.LocalCacheManager
-
- getUsage() - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- getUsage() - Method in class alluxio.client.file.cache.QuotaPageMetaStore
-
- getUsage() - Method in class alluxio.client.file.cache.store.LocalPageStoreDir
-
- getUsage() - Method in class alluxio.client.file.cache.store.MemoryPageStoreDir
-
- getUsageOnTiers() - Method in class alluxio.wire.WorkerWebUIOverview
-
Gets usage on tiers.
- getUsed() - Method in class alluxio.wire.Capacity
-
- getUsedBytes() - Method in interface alluxio.client.block.BlockMasterClient
-
Gets the total amount of used space in bytes, on all the tiers of all the workers.
- getUsedBytes() - Method in class alluxio.client.block.BlockStoreClient
-
Gets the used bytes of Alluxio's BlockStore.
- getUsedBytes() - Method in class alluxio.client.block.BlockWorkerInfo
-
- getUsedBytes() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getUsedBytes(GetUsedBytesPOptions, StreamObserver<GetUsedBytesPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
-
Returns the used storage (in bytes).
- getUsedBytes(GetUsedBytesPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
-
Returns the used storage (in bytes).
- getUsedBytes(GetUsedBytesPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
-
Returns the used storage (in bytes).
- getUsedBytes(GetUsedBytesPOptions, StreamObserver<GetUsedBytesPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
-
Returns the used storage (in bytes).
- getUsedBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 usedBytes = 6;
- getUsedBytes() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int64 usedBytes = 6;
- getUsedBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int64 usedBytes = 6;
- getUsedBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 usedBytes = 6;
- getUsedBytes() - Method in class alluxio.grpc.WorkerInfo
-
optional int64 usedBytes = 6;
- getUsedBytes() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional int64 usedBytes = 6;
- getUsedBytes() - Method in interface alluxio.master.block.BlockMaster
-
- getUsedBytes(GetUsedBytesPOptions, StreamObserver<GetUsedBytesPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
-
- getUsedBytes() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getUsedBytes() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- getUsedBytes() - Method in class alluxio.util.webui.UIStorageDir
-
Gets used bytes.
- getUsedBytes() - Method in class alluxio.util.webui.UIUsageOnTier
-
Gets used bytes.
- getUsedBytes() - Method in class alluxio.wire.BlockMasterInfo
-
- getUsedBytes() - Method in class alluxio.wire.JournalDiskInfo
-
- getUsedBytes() - Method in class alluxio.wire.WorkerInfo
-
- getUsedBytes() - Method in class alluxio.wire.WorkerWebUIOverview
-
Gets used bytes.
- getUsedBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
-
- getUsedBytes() - Method in class alluxio.worker.block.BlockWorkerMetrics
-
- getUsedBytesOnDirs() - Method in interface alluxio.worker.block.BlockStoreMeta
-
- getUsedBytesOnTier() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the space used in bytes on the target tier
- getUsedBytesOnTier() - Method in class alluxio.grpc.CommitBlockPRequest
-
the space used in bytes on the target tier
- getUsedBytesOnTier() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the space used in bytes on the target tier
- getUsedBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
Deprecated.
- getUsedBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
Deprecated.
- getUsedBytesOnTiers() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
Deprecated.
- getUsedBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
Deprecated.
- getUsedBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo
-
Deprecated.
- getUsedBytesOnTiers() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
Deprecated.
- getUsedBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
Deprecated.
- getUsedBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
Deprecated.
- getUsedBytesOnTiers() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
Deprecated.
- getUsedBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
-
Deprecated.
- getUsedBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo
-
Deprecated.
- getUsedBytesOnTiers() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
Deprecated.
- getUsedBytesOnTiers() - Method in interface alluxio.master.block.BlockMaster
-
- getUsedBytesOnTiers() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getUsedBytesOnTiers() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- getUsedBytesOnTiers() - Method in class alluxio.wire.BlockMasterInfo
-
- getUsedBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
-
- getUsedBytesOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
-
- getUsedBytesOnTiers() - Method in class alluxio.worker.block.BlockWorkerMetrics
-
- getUsedBytesOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- getUsedBytesOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
- getUsedBytesOnTiersCount() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of space used in bytes on all tiers
- getUsedBytesOnTiersCount() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- getUsedBytesOnTiersCount() - Method in class alluxio.grpc.BlockMasterInfo
-
- getUsedBytesOnTiersCount() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
map<string, int64> usedBytesOnTiers = 7;
- getUsedBytesOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- getUsedBytesOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
- getUsedBytesOnTiersCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of used bytes on each tier
- getUsedBytesOnTiersCount() - Method in class alluxio.grpc.WorkerInfo.Builder
-
- getUsedBytesOnTiersCount() - Method in class alluxio.grpc.WorkerInfo
-
- getUsedBytesOnTiersCount() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
map<string, int64> usedBytesOnTiers = 9;
- getUsedBytesOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of space used in bytes on all tiers
- getUsedBytesOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of space used in bytes on all tiers
- getUsedBytesOnTiersMap() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of space used in bytes on all tiers
- getUsedBytesOnTiersMap() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
map<string, int64> usedBytesOnTiers = 7;
- getUsedBytesOnTiersMap() - Method in class alluxio.grpc.BlockMasterInfo
-
map<string, int64> usedBytesOnTiers = 7;
- getUsedBytesOnTiersMap() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
map<string, int64> usedBytesOnTiers = 7;
- getUsedBytesOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of used bytes on each tier
- getUsedBytesOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of used bytes on each tier
- getUsedBytesOnTiersMap() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of used bytes on each tier
- getUsedBytesOnTiersMap() - Method in class alluxio.grpc.WorkerInfo.Builder
-
map<string, int64> usedBytesOnTiers = 9;
- getUsedBytesOnTiersMap() - Method in class alluxio.grpc.WorkerInfo
-
map<string, int64> usedBytesOnTiers = 9;
- getUsedBytesOnTiersMap() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
map<string, int64> usedBytesOnTiers = 9;
- getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of space used in bytes on all tiers
- getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of space used in bytes on all tiers
- getUsedBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of space used in bytes on all tiers
- getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
map<string, int64> usedBytesOnTiers = 7;
- getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockMasterInfo
-
map<string, int64> usedBytesOnTiers = 7;
- getUsedBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
map<string, int64> usedBytesOnTiers = 7;
- getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of used bytes on each tier
- getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of used bytes on each tier
- getUsedBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of used bytes on each tier
- getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.WorkerInfo.Builder
-
map<string, int64> usedBytesOnTiers = 9;
- getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.WorkerInfo
-
map<string, int64> usedBytesOnTiers = 9;
- getUsedBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
map<string, int64> usedBytesOnTiers = 9;
- getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of space used in bytes on all tiers
- getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of space used in bytes on all tiers
- getUsedBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of space used in bytes on all tiers
- getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
map<string, int64> usedBytesOnTiers = 7;
- getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockMasterInfo
-
map<string, int64> usedBytesOnTiers = 7;
- getUsedBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
map<string, int64> usedBytesOnTiers = 7;
- getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of used bytes on each tier
- getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of used bytes on each tier
- getUsedBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of used bytes on each tier
- getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.WorkerInfo.Builder
-
map<string, int64> usedBytesOnTiers = 9;
- getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.WorkerInfo
-
map<string, int64> usedBytesOnTiers = 9;
- getUsedBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
map<string, int64> usedBytesOnTiers = 9;
- GetUsedBytesPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetUsedBytesPOptions
- GetUsedBytesPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetUsedBytesPOptions
- GetUsedBytesPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetUsedBytesPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetUsedBytesPResponse
- GetUsedBytesPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetUsedBytesPResponse
- GetUsedBytesPResponseOrBuilder - Interface in alluxio.grpc
-
- getUsedCapacity() - Method in class alluxio.util.webui.StorageTierInfo
-
Gets used capacity.
- getUsedCapacity() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets used capacity.
- getUsedCapacityOnTiers() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get used capacity by tiers.
- getUsedMemory() - Method in class alluxio.util.webui.NodeInfo
-
Gets used memory.
- getUsedSpacePercent() - Method in class alluxio.util.webui.NodeInfo
-
Gets used space percent.
- getUsedSpacePercent() - Method in class alluxio.util.webui.StorageTierInfo
-
Gets used space percent.
- getUsedThroughput(Meter) - Method in class alluxio.underfs.UfsIOManager
-
Get used throughput.
- getUseMultipartUpload() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool useMultipartUpload = 17;
- getUseMultipartUpload() - Method in class alluxio.grpc.CreateFilePOptions
-
optional bool useMultipartUpload = 17;
- getUseMultipartUpload() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional bool useMultipartUpload = 17;
- getUser() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
optional string user = 4;
- getUser() - Method in class alluxio.grpc.UfsReadOptions
-
optional string user = 4;
- getUser() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
-
optional string user = 4;
- getUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The client does not need to set this.
- getUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
The client does not need to set this.
- getUser() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
The client does not need to set this.
- getUser() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional string user = 6;
- getUser() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional string user = 6;
- getUser() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional string user = 6;
- getUser() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional string user = 5;
- getUser() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional string user = 5;
- getUser() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional string user = 5;
- getUser() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional string user = 6;
- getUser() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional string user = 6;
- getUser() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional string user = 6;
- getUser() - Method in class alluxio.proxy.s3.S3Handler
-
Get the user name of this request.
- getUser(String, ContainerRequestContext) - Static method in class alluxio.proxy.s3.S3RestUtils
-
Get username from header info.
- getUser(String, HttpServletRequest) - Static method in class alluxio.proxy.s3.S3RestUtils
-
Get username from header info from HttpServletRequest.
- getUser(HttpRequest) - Static method in class alluxio.s3.NettyRestUtils
-
Get username from header info from FullHttpRequest.
- getUser() - Method in class alluxio.security.user.BaseUserState
-
- getUser() - Method in interface alluxio.security.user.UserState
-
Returns the User object for this user.
- getUser() - Method in class alluxio.worker.s3.S3NettyHandler
-
Get the user name of this request.
- getUserActions(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActions(int) - Method in class alluxio.proto.shared.Acl.AccessControlList
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActions(int) - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsCount() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsCount() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsCount() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsList() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsList() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsOrBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsOrBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsOrBuilder(int) - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsOrBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsOrBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserActionsOrBuilderList() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- getUserAgentString(String, List<String>) - Static method in class alluxio.check.UpdateCheck
-
- getUserBytes() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
optional string user = 4;
- getUserBytes() - Method in class alluxio.grpc.UfsReadOptions
-
optional string user = 4;
- getUserBytes() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
-
optional string user = 4;
- getUserBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The client does not need to set this.
- getUserBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
The client does not need to set this.
- getUserBytes() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
The client does not need to set this.
- getUserBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional string user = 6;
- getUserBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional string user = 6;
- getUserBytes() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional string user = 6;
- getUserBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional string user = 5;
- getUserBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional string user = 5;
- getUserBytes() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional string user = 5;
- getUserBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional string user = 6;
- getUserBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional string user = 6;
- getUserBytes() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional string user = 6;
- getUserChannel(AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
-
Gets the ChannelType properly from the USER_NETWORK_NETTY_CHANNEL property key.
- getUserFromAuthorization(String, AlluxioConfiguration) - Static method in class alluxio.proxy.s3.S3RestUtils
-
Gets the user from the authorization header string for AWS Signature Version 4.
- getUserFromAuthorization(String, AlluxioConfiguration) - Static method in class alluxio.s3.NettyRestUtils
-
Gets the user from the authorization header string for AWS Signature Version 4.
- getUserInfoForChannel(UUID) - Method in interface alluxio.security.authentication.AuthenticationServer
-
- getUserInfoForChannel(UUID) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
-
- getUserName(long) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Gets the user name from the user id.
- getUserState() - Method in class alluxio.client.block.stream.BlockWorkerClientPool
-
- getUserState() - Method in class alluxio.ClientContext
-
- getUserState() - Method in class alluxio.common.RpcPortHealthCheckClient
-
- getUserState() - Method in class alluxio.master.MasterContext
-
- getUuid() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional string uuid = 3;
- getUuid() - Method in class alluxio.grpc.CompleteFilePRequest
-
optional string uuid = 3;
- getUuid() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
-
optional string uuid = 3;
- getUuid() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
uuid of its open file handle
- getUuid() - Method in class alluxio.grpc.CreateFilePResponse
-
uuid of its open file handle
- getUuid() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
-
uuid of its open file handle
- getUUID() - Method in class alluxio.worker.dora.OpenFileHandle
-
Get UUID.
- getUuidBytes() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional string uuid = 3;
- getUuidBytes() - Method in class alluxio.grpc.CompleteFilePRequest
-
optional string uuid = 3;
- getUuidBytes() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
-
optional string uuid = 3;
- getUuidBytes() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
uuid of its open file handle
- getUuidBytes() - Method in class alluxio.grpc.CreateFilePResponse
-
uuid of its open file handle
- getUuidBytes() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
-
uuid of its open file handle
- getValidationWithResult() - Method in class alluxio.cli.hms.CreateHmsClientValidationTask
-
- getValue() - Method in enum alluxio.client.file.cache.CacheManager.State
-
- getValue() - Method in enum alluxio.client.ReadType
-
- getValue() - Method in enum alluxio.client.WriteType
-
- getValue() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string value = 3;
- getValue() - Method in class alluxio.grpc.ConfigProperty
-
optional string value = 3;
- getValue() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
-
optional string value = 3;
- getValue() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- getValue() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- getValue() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- getValue() - Method in class alluxio.grpc.Metric.Builder
-
optional double value = 4;
- getValue() - Method in class alluxio.grpc.Metric
-
optional double value = 4;
- getValue() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional double value = 4;
- getValue() - Method in class alluxio.master.meta.checkconf.ConfigRecord
-
- getValue(String) - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
-
- getValue() - Method in class alluxio.metrics.Metric
-
- getValue(String) - Method in interface alluxio.metrics.MultiValueMetricsAggregator
-
Gets the metric value of the given fully qualified metric name.
- getValue(Map<MetricsFilter, Set<Metric>>) - Method in interface alluxio.metrics.SingleValueAggregator
-
Gets the aggregated value from the filtered metrics.
- getValue() - Method in class alluxio.metrics.TimeSeries.DataPoint
-
- getValue() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string value = 2;
- getValue() - Method in class alluxio.proto.journal.File.StringPairEntry
-
optional string value = 2;
- getValue() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
-
optional string value = 2;
- getValue() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string value = 3;
- getValue() - Method in class alluxio.proto.journal.Job.FileFilter
-
required string value = 3;
- getValue() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
-
required string value = 3;
- getValue() - Method in enum alluxio.underfs.UnderFileSystem.SpaceType
-
- getValue() - Method in class alluxio.util.executor.ControllableQueue.DelayNode
-
- getValue() - Method in enum alluxio.wire.CommandType
-
- getValue() - Method in enum alluxio.wire.LoadMetadataType
-
- getValue() - Method in class alluxio.wire.Property
-
- getValueBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- getValueBytes() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string value = 3;
- getValueBytes() - Method in class alluxio.grpc.ConfigProperty
-
optional string value = 3;
- getValueBytes() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
-
optional string value = 3;
- getValueBytes() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string value = 2;
- getValueBytes() - Method in class alluxio.proto.journal.File.StringPairEntry
-
optional string value = 2;
- getValueBytes() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
-
optional string value = 2;
- getValueBytes() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string value = 3;
- getValueBytes() - Method in class alluxio.proto.journal.Job.FileFilter
-
required string value = 3;
- getValueBytes() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
-
required string value = 3;
- getValueCase() - Method in class alluxio.grpc.table.Value.Builder
-
- getValueCase() - Method in class alluxio.grpc.table.Value
-
- getValueCase() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
- getValueCase() - Method in class alluxio.grpc.WriteRequest.Builder
-
- getValueCase() - Method in class alluxio.grpc.WriteRequest
-
- getValueCase() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
- getValueDescriptor() - Method in enum alluxio.grpc.BackupState
-
- getValueDescriptor() - Method in enum alluxio.grpc.Bits
-
- getValueDescriptor() - Method in enum alluxio.grpc.BlockMasterInfoField
-
- getValueDescriptor() - Method in enum alluxio.grpc.ChannelAuthenticationScheme
-
- getValueDescriptor() - Method in enum alluxio.grpc.CommandType
-
- getValueDescriptor() - Method in enum alluxio.grpc.ConfigStatus
-
- getValueDescriptor() - Method in enum alluxio.grpc.ErrorType
-
- getValueDescriptor() - Method in enum alluxio.grpc.JobMasterMetaCommand
-
- getValueDescriptor() - Method in enum alluxio.grpc.JobProgressReportFormat
-
- getValueDescriptor() - Method in enum alluxio.grpc.JobSource
-
- getValueDescriptor() - Method in enum alluxio.grpc.JobType
-
- getValueDescriptor() - Method in enum alluxio.grpc.JournalDomain
-
- getValueDescriptor() - Method in enum alluxio.grpc.LoadDescendantPType
-
- getValueDescriptor() - Method in enum alluxio.grpc.LoadMetadataPType
-
- getValueDescriptor() - Method in enum alluxio.grpc.MasterInfoField
-
- getValueDescriptor() - Method in enum alluxio.grpc.MetaCommand
-
- getValueDescriptor() - Method in enum alluxio.grpc.MetricType
-
- getValueDescriptor() - Method in enum alluxio.grpc.NodeState
-
- getValueDescriptor() - Method in enum alluxio.grpc.OperationType
-
- getValueDescriptor() - Method in enum alluxio.grpc.PAclAction
-
- getValueDescriptor() - Method in enum alluxio.grpc.PAclEntryType
-
- getValueDescriptor() - Method in enum alluxio.grpc.QuorumServerState
-
- getValueDescriptor() - Method in enum alluxio.grpc.ReadPType
-
- getValueDescriptor() - Method in enum alluxio.grpc.RequestType
-
- getValueDescriptor() - Method in enum alluxio.grpc.SaslMessageType
-
- getValueDescriptor() - Method in enum alluxio.grpc.Scope
-
- getValueDescriptor() - Method in enum alluxio.grpc.ServiceType
-
- getValueDescriptor() - Method in enum alluxio.grpc.SetAclAction
-
- getValueDescriptor() - Method in enum alluxio.grpc.Status
-
- getValueDescriptor() - Method in enum alluxio.grpc.SyncPointStatus
-
- getValueDescriptor() - Method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
-
- getValueDescriptor() - Method in enum alluxio.grpc.table.PrincipalType
-
- getValueDescriptor() - Method in enum alluxio.grpc.table.TableInfo.TableType
-
- getValueDescriptor() - Method in enum alluxio.grpc.TaskStatus
-
- getValueDescriptor() - Method in enum alluxio.grpc.TtlAction
-
- getValueDescriptor() - Method in enum alluxio.grpc.UfsPMode
-
- getValueDescriptor() - Method in enum alluxio.grpc.WorkerInfoField
-
- getValueDescriptor() - Method in enum alluxio.grpc.WorkerRange
-
- getValueDescriptor() - Method in enum alluxio.grpc.WritePType
-
- getValueDescriptor() - Method in enum alluxio.grpc.XAttrPropagationStrategy
-
- getValueDescriptor() - Method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
-
- getValueDescriptor() - Method in enum alluxio.proto.dataserver.Protocol.RequestType
-
- getValueDescriptor() - Method in enum alluxio.proto.journal.File.PSetAclAction
-
- getValueDescriptor() - Method in enum alluxio.proto.journal.File.PTtlAction
-
- getValueDescriptor() - Method in enum alluxio.proto.journal.File.UfsMode
-
- getValueDescriptor() - Method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
-
- getValueDescriptor() - Method in enum alluxio.proto.journal.Job.PJobState
-
- getValueDescriptor() - Method in enum alluxio.proto.shared.Acl.AclAction
-
- getValueDescriptor() - Method in enum alluxio.proto.shared.Acl.AclEntryType
-
- getValueDescriptor() - Method in enum alluxio.proto.status.Status.PStatus
-
- getValueFromStaticMapping(String, String) - Static method in class alluxio.util.CommonUtils
-
Gets the value with a given key from a static key/value mapping in string format.
- getValueOrBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- getValueOrBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- getValueOrBuilder() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- getValues() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
Deprecated.
- getValues() - Method in class alluxio.grpc.InconsistentProperty
-
Deprecated.
- getValues() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
-
Deprecated.
- getValues(int) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
repeated string values = 1;
- getValues(int) - Method in class alluxio.grpc.InconsistentPropertyValues
-
repeated string values = 1;
- getValues(int) - Method in interface alluxio.grpc.InconsistentPropertyValuesOrBuilder
-
repeated string values = 1;
- getValues(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
list of string values for each partition column
- getValues(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
list of string values for each partition column
- getValues(int) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
list of string values for each partition column
- getValues() - Method in class alluxio.wire.InconsistentProperty
-
- getValuesBytes(int) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
repeated string values = 1;
- getValuesBytes(int) - Method in class alluxio.grpc.InconsistentPropertyValues
-
repeated string values = 1;
- getValuesBytes(int) - Method in interface alluxio.grpc.InconsistentPropertyValuesOrBuilder
-
repeated string values = 1;
- getValuesBytes(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
list of string values for each partition column
- getValuesBytes(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
list of string values for each partition column
- getValuesBytes(int) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
list of string values for each partition column
- getValuesCount() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- getValuesCount() - Method in class alluxio.grpc.InconsistentProperty
-
- getValuesCount() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- getValuesCount() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
repeated string values = 1;
- getValuesCount() - Method in class alluxio.grpc.InconsistentPropertyValues
-
repeated string values = 1;
- getValuesCount() - Method in interface alluxio.grpc.InconsistentPropertyValuesOrBuilder
-
repeated string values = 1;
- getValuesCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
list of string values for each partition column
- getValuesCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
list of string values for each partition column
- getValuesCount() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
list of string values for each partition column
- getValueSetCase() - Method in class alluxio.grpc.table.Domain.Builder
-
- getValueSetCase() - Method in class alluxio.grpc.table.Domain
-
- getValueSetCase() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
- getValuesList() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
repeated string values = 1;
- getValuesList() - Method in class alluxio.grpc.InconsistentPropertyValues
-
repeated string values = 1;
- getValuesList() - Method in interface alluxio.grpc.InconsistentPropertyValuesOrBuilder
-
repeated string values = 1;
- getValuesList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
list of string values for each partition column
- getValuesList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
list of string values for each partition column
- getValuesList() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
list of string values for each partition column
- getValuesMap() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- getValuesMap() - Method in class alluxio.grpc.InconsistentProperty
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- getValuesMap() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- getValuesOrDefault(String, InconsistentPropertyValues) - Method in class alluxio.grpc.InconsistentProperty.Builder
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- getValuesOrDefault(String, InconsistentPropertyValues) - Method in class alluxio.grpc.InconsistentProperty
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- getValuesOrDefault(String, InconsistentPropertyValues) - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- getValuesOrThrow(String) - Method in class alluxio.grpc.InconsistentProperty.Builder
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- getValuesOrThrow(String) - Method in class alluxio.grpc.InconsistentProperty
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- getValuesOrThrow(String) - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
-
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
- getVerbose() - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
optional bool verbose = 2;
- getVerbose() - Method in class alluxio.grpc.JobProgressPOptions
-
optional bool verbose = 2;
- getVerbose() - Method in interface alluxio.grpc.JobProgressPOptionsOrBuilder
-
optional bool verbose = 2;
- getVerify() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool verify = 2;
- getVerify() - Method in class alluxio.grpc.CopyJobPOptions
-
optional bool verify = 2;
- getVerify() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional bool verify = 2;
- getVerify() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool verify = 2;
- getVerify() - Method in class alluxio.grpc.LoadJobPOptions
-
optional bool verify = 2;
- getVerify() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
-
optional bool verify = 2;
- getVerify() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool verify = 2;
- getVerify() - Method in class alluxio.grpc.MoveJobPOptions
-
optional bool verify = 2;
- getVerify() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional bool verify = 2;
- getVerify() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required bool verify = 5;
- getVerify() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required bool verify = 5;
- getVerify() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required bool verify = 5;
- getVerify() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required bool verify = 4;
- getVerify() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required bool verify = 4;
- getVerify() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required bool verify = 4;
- getVerify() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required bool verify = 5;
- getVerify() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required bool verify = 5;
- getVerify() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required bool verify = 5;
- getVersion() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get Alluxio version.
- getVersion() - Method in class alluxio.grpc.BuildVersion.Builder
-
the project version
- getVersion() - Method in class alluxio.grpc.BuildVersion
-
the project version
- getVersion() - Method in interface alluxio.grpc.BuildVersionOrBuilder
-
the project version
- getVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
optional int64 version = 1;
- getVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse
-
optional int64 version = 1;
- getVersion() - Method in interface alluxio.grpc.GetServiceVersionPResponseOrBuilder
-
optional int64 version = 1;
- getVersion() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersion() - Method in class alluxio.grpc.JobMasterStatus
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersion() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersion() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional .alluxio.grpc.BuildVersion version = 8;
- getVersion() - Method in class alluxio.grpc.JobWorkerHealth
-
optional .alluxio.grpc.BuildVersion version = 8;
- getVersion() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 8;
- getVersion() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string version = 7;
- getVersion() - Method in class alluxio.grpc.MasterInfo
-
optional string version = 7;
- getVersion() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional string version = 7;
- getVersion() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string version = 2;
- getVersion() - Method in class alluxio.grpc.MasterVersion
-
optional string version = 2;
- getVersion() - Method in interface alluxio.grpc.MasterVersionOrBuilder
-
optional string version = 2;
- getVersion() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersion() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersion() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersion() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 5;
- getVersion() - Method in class alluxio.grpc.ProxyStatus
-
optional .alluxio.grpc.BuildVersion version = 5;
- getVersion() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 5;
- getVersion() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersion() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersion() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersion() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersion() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersion() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersion() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string version = 4;
- getVersion() - Method in class alluxio.grpc.RegisterMasterPOptions
-
optional string version = 4;
- getVersion() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
optional string version = 4;
- getVersion() - Method in class alluxio.grpc.table.Partition.Builder
-
optional int64 version = 4;
- getVersion() - Method in class alluxio.grpc.table.Partition
-
optional int64 version = 4;
- getVersion() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
optional int64 version = 4;
- getVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 version = 10;
- getVersion() - Method in class alluxio.grpc.table.TableInfo
-
optional int64 version = 10;
- getVersion() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional int64 version = 10;
- getVersion() - Method in class alluxio.grpc.WorkerIdentity.Builder
-
version of the definition of the opaque identifier
- getVersion() - Method in class alluxio.grpc.WorkerIdentity
-
version of the definition of the opaque identifier
- getVersion() - Method in interface alluxio.grpc.WorkerIdentityOrBuilder
-
version of the definition of the opaque identifier
- getVersion() - Method in class alluxio.job.MasterWorkerInfo
-
- getVersion() - Method in class alluxio.job.wire.JobWorkerHealth
-
- getVersion() - Method in class alluxio.master.backcompat.Journal
-
- getVersion() - Method in class alluxio.master.meta.JobMasterInfo
-
- getVersion() - Method in class alluxio.master.meta.MasterInfo
-
- getVersion() - Method in class alluxio.master.meta.ProxyInfo
-
- getVersion() - Method in class alluxio.s3.signature.SignatureInfo
-
- getVersion() - Method in class alluxio.underfs.cosn.CosNUnderFileSystemFactory
-
- getVersion() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
-
- getVersion() - Method in class alluxio.underfs.ozone.OzoneUnderFileSystemFactory
-
- getVersion() - Method in interface alluxio.underfs.UnderFileSystemFactory
-
Get the version supported by this factory.
- getVersion() - Method in class alluxio.util.webui.NodeInfo
-
Gets worker version.
- getVersion() - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- getVersion() - Method in class alluxio.wire.AlluxioJobWorkerInfo
-
- getVersion() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getVersion() - Method in class alluxio.wire.AlluxioProxyInfo
-
- getVersion() - Method in class alluxio.wire.AlluxioWorkerInfo
-
- getVersion() - Method in class alluxio.wire.MasterInfo
-
- getVersion() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets version.
- getVersion() - Method in class alluxio.wire.WorkerIdentity.ParserV0
-
- getVersion() - Method in class alluxio.wire.WorkerIdentity.ParserV1
-
- getVersion() - Method in class alluxio.wire.WorkerInfo
-
- getVersion() - Method in class alluxio.wire.WorkerWebUIOverview
-
Gets version.
- getVersion() - Method in class alluxio.worker.http.HttpRequestUri
-
Get the version of the request URI.
- getVersionBuilder() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersionBuilder() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional .alluxio.grpc.BuildVersion version = 8;
- getVersionBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersionBuilder() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 5;
- getVersionBuilder() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersionBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersionBytes() - Method in class alluxio.grpc.BuildVersion.Builder
-
the project version
- getVersionBytes() - Method in class alluxio.grpc.BuildVersion
-
the project version
- getVersionBytes() - Method in interface alluxio.grpc.BuildVersionOrBuilder
-
the project version
- getVersionBytes() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string version = 7;
- getVersionBytes() - Method in class alluxio.grpc.MasterInfo
-
optional string version = 7;
- getVersionBytes() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional string version = 7;
- getVersionBytes() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string version = 2;
- getVersionBytes() - Method in class alluxio.grpc.MasterVersion
-
optional string version = 2;
- getVersionBytes() - Method in interface alluxio.grpc.MasterVersionOrBuilder
-
optional string version = 2;
- getVersionBytes() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string version = 4;
- getVersionBytes() - Method in class alluxio.grpc.RegisterMasterPOptions
-
optional string version = 4;
- getVersionBytes() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
optional string version = 4;
- getVersionCreationTime() - Method in class alluxio.grpc.table.Partition.Builder
-
optional int64 version_creation_time = 5;
- getVersionCreationTime() - Method in class alluxio.grpc.table.Partition
-
optional int64 version_creation_time = 5;
- getVersionCreationTime() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
optional int64 version_creation_time = 5;
- getVersionCreationTime() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 version_creation_time = 11;
- getVersionCreationTime() - Method in class alluxio.grpc.table.TableInfo
-
optional int64 version_creation_time = 11;
- getVersionCreationTime() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional int64 version_creation_time = 11;
- getVersionId() - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
-
- getVersionId() - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
-
- getVersionOrBuilder() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersionOrBuilder() - Method in class alluxio.grpc.JobMasterStatus
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersionOrBuilder() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersionOrBuilder() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional .alluxio.grpc.BuildVersion version = 8;
- getVersionOrBuilder() - Method in class alluxio.grpc.JobWorkerHealth
-
optional .alluxio.grpc.BuildVersion version = 8;
- getVersionOrBuilder() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 8;
- getVersionOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersionOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersionOrBuilder() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersionOrBuilder() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 5;
- getVersionOrBuilder() - Method in class alluxio.grpc.ProxyStatus
-
optional .alluxio.grpc.BuildVersion version = 5;
- getVersionOrBuilder() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 5;
- getVersionOrBuilder() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersionOrBuilder() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersionOrBuilder() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 4;
- getVersionOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersionOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersionOrBuilder() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 3;
- getVersionSpecificRepresentation0(WorkerIdentity) - Method in class alluxio.wire.WorkerIdentity.ParserV0
-
- getVersionSpecificRepresentation0(WorkerIdentity) - Method in class alluxio.wire.WorkerIdentity.ParserV1
-
- getViewingOffset() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets viewing offset.
- getViewingOffset() - Method in class alluxio.wire.MasterWebUILogs
-
Gets viewing offset.
- getViewingOffset() - Method in class alluxio.wire.WorkerWebUILogs
-
Gets viewing offset.
- getVolatileBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
-
Gets the metadata of a block given its block id or empty if block does not exist.
- getWaitTimeNanos(long) - Method in interface alluxio.util.RateLimiter
-
Checks how long is needed to wait for this permit to be ready.
- getWaitTimeNanos(long) - Method in class alluxio.util.SimpleRateLimiter
-
- getWarns() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Deprecated.
- getWarns() - Method in class alluxio.grpc.ConfigCheckReport
-
Deprecated.
- getWarns() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Deprecated.
- getWarnsCount() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- getWarnsCount() - Method in class alluxio.grpc.ConfigCheckReport
-
- getWarnsCount() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Scope name as key
- getWarnsMap() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Scope name as key
- getWarnsMap() - Method in class alluxio.grpc.ConfigCheckReport
-
Scope name as key
- getWarnsMap() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Scope name as key
- getWarnsOrDefault(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Scope name as key
- getWarnsOrDefault(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport
-
Scope name as key
- getWarnsOrDefault(String, InconsistentProperties) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Scope name as key
- getWarnsOrThrow(String) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
Scope name as key
- getWarnsOrThrow(String) - Method in class alluxio.grpc.ConfigCheckReport
-
Scope name as key
- getWarnsOrThrow(String) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
Scope name as key
- getWarnTimeExceeded() - Method in class alluxio.util.JvmPauseMonitor
-
- getWebAddress() - Method in class alluxio.master.MasterProcess
-
- getWebAddress() - Method in class alluxio.worker.AlluxioJobWorkerProcess
-
- getWebAddress() - Method in interface alluxio.worker.JobWorkerProcess
-
- getWebBindAddress() - Method in class alluxio.master.MasterProcess
-
- getWebBindHost() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getWebBindHost() - Method in interface alluxio.worker.WorkerProcess
-
- getWebFileInfoEnabled() - Method in class alluxio.wire.MasterWebUIInit
-
Gets web file info enabled.
- getWebFileInfoEnabled() - Method in class alluxio.wire.WorkerWebUIInit
-
Gets web file info enabled.
- getWebLocalPort() - Method in class alluxio.proxy.AlluxioProxyProcess
-
- getWebLocalPort() - Method in interface alluxio.proxy.ProxyProcess
-
- getWebLocalPort() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getWebLocalPort() - Method in interface alluxio.worker.WorkerProcess
-
- getWebPort() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get web port.
- getWebPort() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int32 webPort = 8;
- getWebPort() - Method in class alluxio.grpc.MasterInfo
-
optional int32 webPort = 8;
- getWebPort() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional int32 webPort = 8;
- getWebPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 webPort = 4;
- getWebPort() - Method in class alluxio.grpc.WorkerNetAddress
-
optional int32 webPort = 4;
- getWebPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional int32 webPort = 4;
- getWebPort() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getWebPort() - Method in interface alluxio.master.meta.MetaMaster
-
- getWebPort() - Method in class alluxio.multi.process.MasterNetAddress
-
- getWebPort() - Method in class alluxio.util.webui.NodeInfo
-
Gets web port.
- getWebPort() - Method in class alluxio.wire.WorkerNetAddress
-
- getWebUIBrowse(String, String, String, String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
Gets Web UI browse page data.
- getWebUIConfiguration() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
Gets Web UI Configuration page data.
- getWebUIData(String, String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
Gets Web UI data page data.
- getWebUIInit() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
Gets Web UI initialization data.
- getWebUILogs(String, String, String, String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
Gets Web UI logs page data.
- getWebUIMasters() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
Gets Web UI Master page data.
- getWebUIMetrics() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
Gets Web UI metrics page data.
- getWebUIMountTable() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
Gets Web UI mount table page data.
- getWebUIOverview() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
Gets Web UI overview page data.
- getWebUIWorkers() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
Gets Web UI workers page data.
- getWhiteList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
optional bool white_list = 2;
- getWhiteList() - Method in class alluxio.grpc.table.EquatableValueSet
-
optional bool white_list = 2;
- getWhiteList() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
optional bool white_list = 2;
- getWhiteList() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getWhiteList() - Method in interface alluxio.master.file.FileSystemMaster
-
- getWhitelist() - Method in class alluxio.wire.MasterWebUIConfiguration
-
Gets whitelist.
- getWhitelist() - Method in class alluxio.wire.WorkerWebUIConfiguration
-
Gets whitelist.
- getWhiteList() - Method in interface alluxio.worker.block.BlockWorker
-
- getWid() - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
-
- getWidthNano() - Method in class alluxio.job.util.TimeSeries
-
- getWorker(long) - Method in interface alluxio.master.block.BlockMaster
-
- getWorker(long) - Method in class alluxio.master.block.DefaultBlockMaster
-
- getWorker() - Method in class alluxio.master.LocalAlluxioJobCluster
-
- getWorker(Class<T>) - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getWorker() - Method in class alluxio.worker.netty.FileReadHandler
-
Gets worker.
- getWorker() - Method in class alluxio.worker.netty.FileWriteHandler
-
- getWorker(Class<T>) - Method in interface alluxio.worker.WorkerProcess
-
- getWorkerAddress() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- getWorkerAddress() - Method in class alluxio.grpc.BlockLocation
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- getWorkerAddress() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- getWorkerAddress() - Method in class alluxio.job.MasterWorkerInfo
-
- getWorkerAddress() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- getWorkerAddress() - Method in class alluxio.master.LocalAlluxioCluster
-
- getWorkerAddress() - Method in class alluxio.util.webui.UIWorkerInfo
-
Gets worker address.
- getWorkerAddress() - Method in class alluxio.wire.BlockLocation
-
- getWorkerAddress() - Method in interface alluxio.worker.block.BlockWorker
-
- getWorkerAddressBuilder() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- getWorkerAddresses(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddresses(int) - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddresses(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddresses() - Method in interface alluxio.master.block.BlockMaster
-
- getWorkerAddresses() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getWorkerAddresses() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getWorkerAddresses() - Method in interface alluxio.master.meta.MetaMaster
-
- getWorkerAddressesBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesCount() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesCount() - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesCount() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesList() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesList() - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesOrBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesOrBuilder(int) - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesOrBuilder(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesOrBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesOrBuilderList() - Method in class alluxio.grpc.MasterInfo
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressesOrBuilderList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- getWorkerAddressOrBuilder() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- getWorkerAddressOrBuilder() - Method in class alluxio.grpc.BlockLocation
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- getWorkerAddressOrBuilder() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- getWorkerAssignPolicy() - Method in class alluxio.master.job.AbstractJob
-
Gets the worker assign policy.
- getWorkerCapacityFreePercentage() - Method in class alluxio.wire.WorkerWebUIMetrics
-
Gets worker capacity free percentage.
- getWorkerCapacityUsedPercentage() - Method in class alluxio.wire.WorkerWebUIMetrics
-
Gets worker capacity used percentage.
- getWorkerChannel(AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
-
Gets the worker channel properly from the WORKER_NETWORK_NETTY_CHANNEL property key.
- getWorkerClient(WorkerNetAddress) - Method in class alluxio.master.scheduler.DefaultWorkerProvider
-
- getWorkerClient(WorkerNetAddress) - Method in class alluxio.master.scheduler.MembershipManagerWorkerProvider
-
- getWorkerClient(WorkerNetAddress) - Method in interface alluxio.master.scheduler.WorkerProvider
-
Gets a worker client.
- getWorkerCount() - Method in interface alluxio.master.block.BlockMaster
-
- getWorkerCount() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getWorkerDataDirectory(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
-
- getWorkerHealth() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Get worker health info.
- getWorkerHealths(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealths(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealths(int) - Method in interface alluxio.grpc.GetAllWorkerHealthPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsBuilder(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsBuilderList() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsCount() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsCount() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsCount() - Method in interface alluxio.grpc.GetAllWorkerHealthPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsList() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsList() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsList() - Method in interface alluxio.grpc.GetAllWorkerHealthPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsOrBuilder(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsOrBuilder(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsOrBuilder(int) - Method in interface alluxio.grpc.GetAllWorkerHealthPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsOrBuilderList() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsOrBuilderList() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHealthsOrBuilderList() - Method in interface alluxio.grpc.GetAllWorkerHealthPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- getWorkerHost() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string workerHost = 12;
- getWorkerHost() - Method in class alluxio.grpc.JobInfo
-
optional string workerHost = 12;
- getWorkerHost() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string workerHost = 12;
- getWorkerHost() - Method in class alluxio.job.plan.replicate.MoveConfig
-
- getWorkerHost() - Method in class alluxio.job.wire.TaskInfo
-
- getWorkerHostBytes() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string workerHost = 12;
- getWorkerHostBytes() - Method in class alluxio.grpc.JobInfo
-
optional string workerHost = 12;
- getWorkerHostBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string workerHost = 12;
- getWorkerHostname() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
required string workerHostname = 1;
- getWorkerHostname() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
required string workerHostname = 1;
- getWorkerHostname() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
-
required string workerHostname = 1;
- getWorkerHostname() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
required string workerHostname = 1;
- getWorkerHostname() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
required string workerHostname = 1;
- getWorkerHostname() - Method in interface alluxio.grpc.RemoveDisabledWorkerPOptionsOrBuilder
-
required string workerHostname = 1;
- getWorkerHostnameBytes() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
required string workerHostname = 1;
- getWorkerHostnameBytes() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
required string workerHostname = 1;
- getWorkerHostnameBytes() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
-
required string workerHostname = 1;
- getWorkerHostnameBytes() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
required string workerHostname = 1;
- getWorkerHostnameBytes() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
required string workerHostname = 1;
- getWorkerHostnameBytes() - Method in interface alluxio.grpc.RemoveDisabledWorkerPOptionsOrBuilder
-
required string workerHostname = 1;
- getWorkerHostnames(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
-
Gets list of workers in conf directory.
- getWorkerId() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the id of the worker
- getWorkerId() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the id of the worker
- getWorkerId() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the id of the worker
- getWorkerId() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.BlockLocation
-
optional int64 workerId = 1;
- getWorkerId() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional int64 workerId = 1;
- getWorkerId(GetWorkerIdPRequest, StreamObserver<GetWorkerIdPResponse>) - Method in interface alluxio.grpc.BlockMasterWorkerServiceGrpc.AsyncService
-
Returns a worker id for the given network address.
- getWorkerId(GetWorkerIdPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub
-
Returns a worker id for the given network address.
- getWorkerId(GetWorkerIdPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub
-
Returns a worker id for the given network address.
- getWorkerId(GetWorkerIdPRequest, StreamObserver<GetWorkerIdPResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
-
Returns a worker id for the given network address.
- getWorkerId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the id of the worker
- getWorkerId() - Method in class alluxio.grpc.CommitBlockPRequest
-
the id of the worker
- getWorkerId() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the id of the worker
- getWorkerId() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
the id of the worker
- getWorkerId() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
the id of the worker
- getWorkerId() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
-
the id of the worker
- getWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePRequest
-
optional int64 workerId = 1;
- getWorkerId() - Method in interface alluxio.grpc.GetRegisterLeasePRequestOrBuilder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
optional int64 workerId = 1;
- getWorkerId() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.GetWorkerIdPResponse
-
optional int64 workerId = 1;
- getWorkerId() - Method in interface alluxio.grpc.GetWorkerIdPResponseOrBuilder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.JobWorkerHealth
-
optional int64 workerId = 1;
- getWorkerId() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
optional int64 workerId = 1;
- getWorkerId() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
-
optional int64 workerId = 1;
- getWorkerId() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the id of the worker
- getWorkerId() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the id of the worker
- getWorkerId() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the id of the worker
- getWorkerId() - Method in class alluxio.job.wire.JobWorkerHealth
-
- getWorkerId(WorkerNetAddress) - Method in interface alluxio.master.block.BlockMaster
-
Returns a worker id for the given worker, creating one if the worker is new.
- getWorkerId(GetWorkerIdPRequest, StreamObserver<GetWorkerIdPResponse>) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
-
- getWorkerId(WorkerNetAddress) - Method in class alluxio.master.block.DefaultBlockMaster
-
- getWorkerId() - Method in class alluxio.master.block.meta.MasterBlockLocation
-
- getWorkerId() - Method in class alluxio.master.block.WorkerRegisterContext
-
Getter for worker ID.
- getWorkerId() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional int64 worker_id = 1;
- getWorkerId() - Method in class alluxio.proto.meta.Block.BlockLocation
-
optional int64 worker_id = 1;
- getWorkerId() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
-
optional int64 worker_id = 1;
- getWorkerId() - Method in class alluxio.util.webui.NodeInfo
-
Gets worker id.
- getWorkerId() - Method in class alluxio.wire.BlockLocation
-
- getWorkerId() - Method in interface alluxio.worker.DataWorker
-
- getWorkerId() - Method in class alluxio.worker.dora.PagedDoraWorker
-
- getWorkerId() - Static method in class alluxio.worker.JobWorkerIdRegistry
-
- getWorkerIdAddressMap() - Method in class alluxio.client.block.AllMastersWorkerInfo
-
- getWorkerIdInfoMap() - Method in class alluxio.client.block.AllMastersWorkerInfo
-
- GetWorkerIdPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerIdPOptions
- GetWorkerIdPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerIdPOptions
- GetWorkerIdPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetWorkerIdPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerIdPRequest
- GetWorkerIdPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerIdPRequest
- GetWorkerIdPRequestOrBuilder - Interface in alluxio.grpc
-
- GetWorkerIdPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerIdPResponse
- GetWorkerIdPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerIdPResponse
- GetWorkerIdPResponseOrBuilder - Interface in alluxio.grpc
-
- getWorkerInfo() - Method in class alluxio.master.block.WorkerRegisterContext
-
- getWorkerInfo() - Method in class alluxio.wire.WorkerWebUIOverview
-
Gets worker info.
- getWorkerInfoHub() - Method in class alluxio.master.scheduler.Scheduler
-
Get the workerinfo hub.
- getWorkerInfoList() - Method in interface alluxio.client.block.BlockMasterClient
-
Gets the worker information of live workers(support older version Alluxio server).
- getWorkerInfoList() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getWorkerInfoList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
-
Returns a list of workers information.
- getWorkerInfoList(GetWorkerInfoListPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
-
Returns a list of workers information.
- getWorkerInfoList(GetWorkerInfoListPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
-
Returns a list of workers information.
- getWorkerInfoList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
-
Returns a list of workers information.
- getWorkerInfoList() - Method in interface alluxio.master.block.BlockMaster
-
- getWorkerInfoList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
-
- getWorkerInfoList() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getWorkerInfoList() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getWorkerInfoList() - Method in interface alluxio.master.file.FileSystemMaster
-
- getWorkerInfoList() - Method in class alluxio.master.file.meta.FileSystemMasterView
-
- getWorkerInfoList() - Method in class alluxio.master.job.JobMaster
-
- GetWorkerInfoListPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerInfoListPOptions
- GetWorkerInfoListPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerInfoListPOptions
- GetWorkerInfoListPOptionsOrBuilder - Interface in alluxio.grpc
-
- GetWorkerInfoListPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerInfoListPResponse
- GetWorkerInfoListPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerInfoListPResponse
- GetWorkerInfoListPResponseOrBuilder - Interface in alluxio.grpc
-
- getWorkerInfos(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfos(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfos(int) - Method in interface alluxio.grpc.GetWorkerInfoListPResponseOrBuilder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfos() - Method in class alluxio.master.scheduler.DefaultWorkerProvider
-
- getWorkerInfos() - Method in class alluxio.master.scheduler.MembershipManagerWorkerProvider
-
- getWorkerInfos() - Method in interface alluxio.master.scheduler.WorkerProvider
-
Gets a list of worker information.
- getWorkerInfosBuilder(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosBuilderList() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosCount() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosCount() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosCount() - Method in interface alluxio.grpc.GetWorkerInfoListPResponseOrBuilder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosList() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosList() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosList() - Method in interface alluxio.grpc.GetWorkerInfoListPResponseOrBuilder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosOrBuilder(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosOrBuilder(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosOrBuilder(int) - Method in interface alluxio.grpc.GetWorkerInfoListPResponseOrBuilder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosOrBuilderList() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosOrBuilderList() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerInfosOrBuilderList() - Method in interface alluxio.grpc.GetWorkerInfoListPResponseOrBuilder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- getWorkerLocation() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
If specified, the data will be written to the certain worker
- getWorkerLocation() - Method in class alluxio.grpc.CreateFilePOptions
-
If specified, the data will be written to the certain worker
- getWorkerLocation() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
If specified, the data will be written to the certain worker
- getWorkerLocationBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
If specified, the data will be written to the certain worker
- getWorkerLocationOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
If specified, the data will be written to the certain worker
- getWorkerLocationOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions
-
If specified, the data will be written to the certain worker
- getWorkerLocationOrBuilder() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
If specified, the data will be written to the certain worker
- getWorkerLostStorage() - Method in interface alluxio.client.block.BlockMasterClient
-
- getWorkerLostStorage() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getWorkerLostStorage(GetWorkerLostStoragePOptions, StreamObserver<GetWorkerLostStoragePResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
-
Returns a list of worker lost storage information
- getWorkerLostStorage(GetWorkerLostStoragePOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
-
Returns a list of worker lost storage information
- getWorkerLostStorage(GetWorkerLostStoragePOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
-
Returns a list of worker lost storage information
- getWorkerLostStorage(GetWorkerLostStoragePOptions, StreamObserver<GetWorkerLostStoragePResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
-
Returns a list of worker lost storage information
- getWorkerLostStorage() - Method in interface alluxio.master.block.BlockMaster
-
- getWorkerLostStorage(GetWorkerLostStoragePOptions, StreamObserver<GetWorkerLostStoragePResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
-
- getWorkerLostStorage() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getWorkerLostStorageInfo(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfo(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfo(int) - Method in interface alluxio.grpc.GetWorkerLostStoragePResponseOrBuilder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoBuilder(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoBuilderList() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoCount() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoCount() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoCount() - Method in interface alluxio.grpc.GetWorkerLostStoragePResponseOrBuilder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoList() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoList() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoList() - Method in interface alluxio.grpc.GetWorkerLostStoragePResponseOrBuilder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoOrBuilder(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoOrBuilder(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoOrBuilder(int) - Method in interface alluxio.grpc.GetWorkerLostStoragePResponseOrBuilder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoOrBuilderList() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoOrBuilderList() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- getWorkerLostStorageInfoOrBuilderList() - Method in interface alluxio.grpc.GetWorkerLostStoragePResponseOrBuilder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- GetWorkerLostStoragePOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerLostStoragePOptions
- GetWorkerLostStoragePOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerLostStoragePOptions
- GetWorkerLostStoragePOptionsOrBuilder - Interface in alluxio.grpc
-
- GetWorkerLostStoragePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerLostStoragePResponse
- GetWorkerLostStoragePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerLostStoragePResponse
- GetWorkerLostStoragePResponseOrBuilder - Interface in alluxio.grpc
-
- getWorkerNetAddress(String) - Method in class alluxio.client.file.dora.DoraCacheClient
-
Get the worker net address of the specific file path.
- getWorkerNetAddress(AlluxioURI) - Method in class alluxio.client.file.DoraCacheFileSystem
-
Get the worker address which the specified file locates at.
- getWorkerNetAddress() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
the worker network address
- getWorkerNetAddress() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
the worker network address
- getWorkerNetAddress() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
-
the worker network address
- getWorkerNetAddress() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
the worker network address
- getWorkerNetAddress() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
the worker network address
- getWorkerNetAddress() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
-
the worker network address
- getWorkerNetAddress() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- getWorkerNetAddress() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- getWorkerNetAddress() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- getWorkerNetAddress() - Method in class alluxio.membership.WorkerServiceEntity
-
Get WorkerNetAddress field.
- getWorkerNetAddressBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
the worker network address
- getWorkerNetAddressBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
the worker network address
- getWorkerNetAddressBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
the worker network address
- getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
the worker network address
- getWorkerNetAddressOrBuilder() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
-
the worker network address
- getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
the worker network address
- getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
the worker network address
- getWorkerNetAddressOrBuilder() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
-
the worker network address
- getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- getWorkerNetAddressOrBuilder() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- getWorkerPort() - Method in class alluxio.wire.MasterWebUIInit
-
Gets worker port.
- getWorkerProcess() - Method in class alluxio.master.LocalAlluxioCluster
-
- getWorkerProcess(int) - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- getWorkerProcess(int) - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- getWorkerRange() - Method in class alluxio.client.block.options.GetWorkerReportOptions
-
- getWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
- getWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
- getWorkerRange() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
-
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
- getWorkerReport(GetWorkerReportOptions) - Method in interface alluxio.client.block.BlockMasterClient
-
Gets the worker information of selected workers and selected fields for report CLI.
- getWorkerReport(GetWorkerReportOptions) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getWorkerReport(GetWorkerReportPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
-
Returns a list of workers information for report CLI.
- getWorkerReport(GetWorkerReportPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
-
Returns a list of workers information for report CLI.
- getWorkerReport(GetWorkerReportPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
-
Returns a list of workers information for report CLI.
- getWorkerReport(GetWorkerReportPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
-
Returns a list of workers information for report CLI.
- getWorkerReport(GetWorkerReportOptions) - Method in interface alluxio.master.block.BlockMaster
-
Gets the worker information list for report CLI.
- getWorkerReport(GetWorkerReportPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
-
- getWorkerReport(GetWorkerReportOptions) - Method in class alluxio.master.block.DefaultBlockMaster
-
- GetWorkerReportOptions - Class in alluxio.client.block.options
-
Worker information options.
- GetWorkerReportOptions(GetWorkerReportPOptions) - Constructor for class alluxio.client.block.options.GetWorkerReportOptions
-
- GetWorkerReportOptions.WorkerInfoField - Enum in alluxio.client.block.options
-
Enum representing the fields of the worker information.
- GetWorkerReportOptions.WorkerRange - Enum in alluxio.client.block.options
-
Enum representing the range of workers that we want to show capacity information for.
- GetWorkerReportPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerReportPOptions
- GetWorkerReportPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.block.GetWorkerReportPOptions
- GetWorkerReportPOptionsOrBuilder - Interface in alluxio.grpc
-
- getWorkerReportsFromAllMasters(AlluxioConfiguration, BlockMasterClient, GetWorkerReportOptions) - Static method in class alluxio.client.block.util.WorkerInfoUtil
-
Get worker reports from all masters, including standby masters.
- getWorkers() - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- getWorkers() - Method in class alluxio.wire.AlluxioMasterInfo
-
- getWorkersThatHaveData() - Method in class alluxio.cli.fs.command.FileLocation
-
Get the workers where data locate.
- getWorkerToTaskQ() - Method in class alluxio.master.scheduler.Scheduler.WorkerInfoHub
-
- getWorkerWebPort() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
optional int64 workerWebPort = 2;
- getWorkerWebPort() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
optional int64 workerWebPort = 2;
- getWorkerWebPort() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
-
optional int64 workerWebPort = 2;
- getWorkerWebPort() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
optional int64 workerWebPort = 2;
- getWorkerWebPort() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
optional int64 workerWebPort = 2;
- getWorkerWebPort() - Method in interface alluxio.grpc.RemoveDisabledWorkerPOptionsOrBuilder
-
optional int64 workerWebPort = 2;
- getWorkerWithMostBlocks(List<BlockWorkerInfo>, List<FileBlockInfo>) - Static method in class alluxio.job.util.JobUtils
-
Returns whichever specified worker stores the most blocks from the block info list.
- getWorkflowConfigClass() - Method in class alluxio.job.workflow.composite.CompositeExecutionFactory
-
- getWorkflowConfigClass() - Method in interface alluxio.job.workflow.WorkflowExecutionFactory
-
- getWorkingDirectory(CommandLine) - Method in class alluxio.cli.bundler.command.AbstractCollectInfoCommand
-
Gets the directory that this command should output to.
- getWorkingDirectory() - Method in class alluxio.hadoop.AbstractFileSystem
-
- getWorkingDirectory() - Method in class alluxio.hadoop.LocalCacheFileSystem
-
- getWriteBlockMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getWriteLock() - Method in class alluxio.master.file.meta.MountTable
-
Returns the underlying write lock of the MountTable.
- getWriteOffset() - Method in class alluxio.fuse.OpenFileEntry
-
- getWriteOptions() - Method in class alluxio.grpc.CopyRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptions() - Method in class alluxio.grpc.CopyRequest
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptions() - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptions() - Method in class alluxio.grpc.MoveRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptions() - Method in class alluxio.grpc.MoveRequest
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptions() - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptionsBuilder() - Method in class alluxio.grpc.CopyRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptionsBuilder() - Method in class alluxio.grpc.MoveRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptionsOrBuilder() - Method in class alluxio.grpc.CopyRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptionsOrBuilder() - Method in class alluxio.grpc.CopyRequest
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptionsOrBuilder() - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptionsOrBuilder() - Method in class alluxio.grpc.MoveRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptionsOrBuilder() - Method in class alluxio.grpc.MoveRequest
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriteOptionsOrBuilder() - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- getWriter() - Method in interface alluxio.master.journalv0.MutableJournal
-
- getWriter() - Method in class alluxio.master.journalv0.ufs.UfsMutableJournal
-
- getWriteSpeedStat() - Method in class alluxio.stress.worker.IOTaskSummary
-
- getWriteTier() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getWriteTier() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 writeTier = 7;
- getWriteTier() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int32 writeTier = 7;
- getWriteTier() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int32 writeTier = 7;
- getWriteType() - Method in class alluxio.client.file.options.OutStreamOptions
-
- getWriteType() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- getWriteType() - Method in class alluxio.grpc.CopyJobPOptions
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- getWriteType() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- getWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
- getWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
- getWriteType() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
- getWriteType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
- getWriteType() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
- getWriteType() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
- getWriteType() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- getWriteType() - Method in class alluxio.grpc.MoveJobPOptions
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- getWriteType() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- getWriteType() - Method in class alluxio.grpc.WriteOptions.Builder
-
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
- getWriteType() - Method in class alluxio.grpc.WriteOptions
-
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
- getWriteType() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
-
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
- getWriteType() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
-
- getWriteType() - Method in class alluxio.job.plan.migrate.MigrateConfig
-
- getWriteType() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getXAttr() - Method in class alluxio.client.file.URIStatus
-
- getXattr() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
Deprecated.
- getXattr() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
Deprecated.
- getXattr() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
Deprecated.
- getXattr() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
Deprecated.
- getXattr() - Method in class alluxio.grpc.CreateFilePOptions
-
Deprecated.
- getXattr() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
Deprecated.
- getXattr() - Method in class alluxio.grpc.FileInfo.Builder
-
Deprecated.
- getXattr() - Method in class alluxio.grpc.FileInfo
-
Deprecated.
- getXattr() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
Deprecated.
- getXattr() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
Deprecated.
- getXattr() - Method in class alluxio.grpc.SetAttributePOptions
-
Deprecated.
- getXattr() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
Deprecated.
- getXattr() - Method in class alluxio.grpc.UfsStatus.Builder
-
Deprecated.
- getXattr() - Method in class alluxio.grpc.UfsStatus
-
Deprecated.
- getXattr() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
Deprecated.
- getXAttr() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getXAttr() - Method in class alluxio.master.file.meta.Inode
-
- getXAttr() - Method in interface alluxio.master.file.meta.InodeView
-
- getXAttr() - Method in class alluxio.master.file.meta.MutableInode
-
- getXAttr() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
Deprecated.
- getXAttr() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
Deprecated.
- getXAttr() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
Deprecated.
- getXAttr() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
Deprecated.
- getXAttr() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
Deprecated.
- getXAttr() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
Deprecated.
- getXAttr() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
Deprecated.
- getXAttr() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
Deprecated.
- getXAttr() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
Deprecated.
- getXAttr() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
Deprecated.
- getXAttr() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
Deprecated.
- getXAttr() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
Deprecated.
- getXAttr() - Method in class alluxio.underfs.UfsStatus
-
Returns the extended attributes from the Ufs, if any.
- getXAttr() - Method in class alluxio.wire.FileInfo
-
- getxattrCallback(String, String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- getXattrCount() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- getXattrCount() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
- getXattrCount() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
map<string, bytes> xattr = 6;
- getXattrCount() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- getXattrCount() - Method in class alluxio.grpc.CreateFilePOptions
-
- getXattrCount() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
map<string, bytes> xattr = 11;
- getXattrCount() - Method in class alluxio.grpc.FileInfo.Builder
-
- getXattrCount() - Method in class alluxio.grpc.FileInfo
-
- getXattrCount() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
map<string, bytes> xattr = 32;
- getXattrCount() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- getXattrCount() - Method in class alluxio.grpc.SetAttributePOptions
-
- getXattrCount() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
map<string, bytes> xattr = 11;
- getXattrCount() - Method in class alluxio.grpc.UfsStatus.Builder
-
- getXattrCount() - Method in class alluxio.grpc.UfsStatus
-
- getXattrCount() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
map<string, bytes> xattr = 7;
- getXAttrCount() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- getXAttrCount() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
- getXAttrCount() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
map<string, bytes> xAttr = 19;
- getXAttrCount() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- getXAttrCount() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
- getXAttrCount() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
map<string, bytes> xAttr = 28;
- getXAttrCount() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- getXAttrCount() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
- getXAttrCount() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
map<string, bytes> xAttr = 17;
- getXAttrCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- getXAttrCount() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
- getXAttrCount() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
Extended attributes, general purpose.
- getXattrMap() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
map<string, bytes> xattr = 6;
- getXattrMap() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
map<string, bytes> xattr = 6;
- getXattrMap() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
map<string, bytes> xattr = 6;
- getXattrMap() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
map<string, bytes> xattr = 11;
- getXattrMap() - Method in class alluxio.grpc.CreateFilePOptions
-
map<string, bytes> xattr = 11;
- getXattrMap() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
map<string, bytes> xattr = 11;
- getXattrMap() - Method in class alluxio.grpc.FileInfo.Builder
-
map<string, bytes> xattr = 32;
- getXattrMap() - Method in class alluxio.grpc.FileInfo
-
map<string, bytes> xattr = 32;
- getXattrMap() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
map<string, bytes> xattr = 32;
- getXattrMap() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
map<string, bytes> xattr = 11;
- getXattrMap() - Method in class alluxio.grpc.SetAttributePOptions
-
map<string, bytes> xattr = 11;
- getXattrMap() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
map<string, bytes> xattr = 11;
- getXattrMap() - Method in class alluxio.grpc.UfsStatus.Builder
-
map<string, bytes> xattr = 7;
- getXattrMap() - Method in class alluxio.grpc.UfsStatus
-
map<string, bytes> xattr = 7;
- getXattrMap() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
map<string, bytes> xattr = 7;
- getXAttrMap() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
map<string, bytes> xAttr = 19;
- getXAttrMap() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
map<string, bytes> xAttr = 19;
- getXAttrMap() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
map<string, bytes> xAttr = 19;
- getXAttrMap() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
map<string, bytes> xAttr = 28;
- getXAttrMap() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
map<string, bytes> xAttr = 28;
- getXAttrMap() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
map<string, bytes> xAttr = 28;
- getXAttrMap() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
map<string, bytes> xAttr = 17;
- getXAttrMap() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
map<string, bytes> xAttr = 17;
- getXAttrMap() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
map<string, bytes> xAttr = 17;
- getXAttrMap() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
Extended attributes, general purpose.
- getXAttrMap() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
Extended attributes, general purpose.
- getXAttrMap() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
Extended attributes, general purpose.
- getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
map<string, bytes> xattr = 6;
- getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.CreateDirectoryPOptions
-
map<string, bytes> xattr = 6;
- getXattrOrDefault(String, ByteString) - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
map<string, bytes> xattr = 6;
- getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
map<string, bytes> xattr = 11;
- getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.CreateFilePOptions
-
map<string, bytes> xattr = 11;
- getXattrOrDefault(String, ByteString) - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
map<string, bytes> xattr = 11;
- getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
map<string, bytes> xattr = 32;
- getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.FileInfo
-
map<string, bytes> xattr = 32;
- getXattrOrDefault(String, ByteString) - Method in interface alluxio.grpc.FileInfoOrBuilder
-
map<string, bytes> xattr = 32;
- getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
map<string, bytes> xattr = 11;
- getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.SetAttributePOptions
-
map<string, bytes> xattr = 11;
- getXattrOrDefault(String, ByteString) - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
map<string, bytes> xattr = 11;
- getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
-
map<string, bytes> xattr = 7;
- getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.UfsStatus
-
map<string, bytes> xattr = 7;
- getXattrOrDefault(String, ByteString) - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
map<string, bytes> xattr = 7;
- getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
map<string, bytes> xAttr = 19;
- getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
map<string, bytes> xAttr = 19;
- getXAttrOrDefault(String, ByteString) - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
map<string, bytes> xAttr = 19;
- getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
map<string, bytes> xAttr = 28;
- getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry
-
map<string, bytes> xAttr = 28;
- getXAttrOrDefault(String, ByteString) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
map<string, bytes> xAttr = 28;
- getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
map<string, bytes> xAttr = 17;
- getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
map<string, bytes> xAttr = 17;
- getXAttrOrDefault(String, ByteString) - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
map<string, bytes> xAttr = 17;
- getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
Extended attributes, general purpose.
- getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode
-
Extended attributes, general purpose.
- getXAttrOrDefault(String, ByteString) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
Extended attributes, general purpose.
- getXattrOrThrow(String) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
map<string, bytes> xattr = 6;
- getXattrOrThrow(String) - Method in class alluxio.grpc.CreateDirectoryPOptions
-
map<string, bytes> xattr = 6;
- getXattrOrThrow(String) - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
map<string, bytes> xattr = 6;
- getXattrOrThrow(String) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
map<string, bytes> xattr = 11;
- getXattrOrThrow(String) - Method in class alluxio.grpc.CreateFilePOptions
-
map<string, bytes> xattr = 11;
- getXattrOrThrow(String) - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
map<string, bytes> xattr = 11;
- getXattrOrThrow(String) - Method in class alluxio.grpc.FileInfo.Builder
-
map<string, bytes> xattr = 32;
- getXattrOrThrow(String) - Method in class alluxio.grpc.FileInfo
-
map<string, bytes> xattr = 32;
- getXattrOrThrow(String) - Method in interface alluxio.grpc.FileInfoOrBuilder
-
map<string, bytes> xattr = 32;
- getXattrOrThrow(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
map<string, bytes> xattr = 11;
- getXattrOrThrow(String) - Method in class alluxio.grpc.SetAttributePOptions
-
map<string, bytes> xattr = 11;
- getXattrOrThrow(String) - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
map<string, bytes> xattr = 11;
- getXattrOrThrow(String) - Method in class alluxio.grpc.UfsStatus.Builder
-
map<string, bytes> xattr = 7;
- getXattrOrThrow(String) - Method in class alluxio.grpc.UfsStatus
-
map<string, bytes> xattr = 7;
- getXattrOrThrow(String) - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
map<string, bytes> xattr = 7;
- getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
map<string, bytes> xAttr = 19;
- getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
map<string, bytes> xAttr = 19;
- getXAttrOrThrow(String) - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
map<string, bytes> xAttr = 19;
- getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
map<string, bytes> xAttr = 28;
- getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.InodeFileEntry
-
map<string, bytes> xAttr = 28;
- getXAttrOrThrow(String) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
map<string, bytes> xAttr = 28;
- getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
map<string, bytes> xAttr = 17;
- getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
map<string, bytes> xAttr = 17;
- getXAttrOrThrow(String) - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
map<string, bytes> xAttr = 17;
- getXAttrOrThrow(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
Extended attributes, general purpose.
- getXAttrOrThrow(String) - Method in class alluxio.proto.meta.InodeMeta.Inode
-
Extended attributes, general purpose.
- getXAttrOrThrow(String) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
Extended attributes, general purpose.
- getXattrPropStrat() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
- getXattrPropStrat() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
- getXattrPropStrat() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
- getXattrPropStrat() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
- getXattrPropStrat() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
- getXattrPropStrat() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
- getXAttrPropStrat() - Method in class alluxio.master.file.contexts.CreatePathContext
-
- getXattrUpdateStrategy() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
- getXattrUpdateStrategy() - Method in class alluxio.grpc.SetAttributePOptions
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
- getXattrUpdateStrategy() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
- getXAttrUpdateStrategy() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
- getXAttrUpdateStrategy() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
- getXAttrUpdateStrategy() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
- getZkAddress() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
-
- getZone() - Method in class alluxio.clock.ElapsedTimeClock
-
- getZone() - Method in class alluxio.clock.SystemClock
-
- getZookeeperAddress() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get zookeeper address.
- getZookeeperAddress() - Method in class alluxio.uri.ZookeeperAuthority
-
- getZookeeperAddresses(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
Empty means zookeeper is not enabled
- getZookeeperAddresses(int) - Method in class alluxio.grpc.MasterInfo
-
Empty means zookeeper is not enabled
- getZookeeperAddresses(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
Empty means zookeeper is not enabled
- getZookeeperAddressesBytes(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
Empty means zookeeper is not enabled
- getZookeeperAddressesBytes(int) - Method in class alluxio.grpc.MasterInfo
-
Empty means zookeeper is not enabled
- getZookeeperAddressesBytes(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
Empty means zookeeper is not enabled
- getZookeeperAddressesCount() - Method in class alluxio.grpc.MasterInfo.Builder
-
Empty means zookeeper is not enabled
- getZookeeperAddressesCount() - Method in class alluxio.grpc.MasterInfo
-
Empty means zookeeper is not enabled
- getZookeeperAddressesCount() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
Empty means zookeeper is not enabled
- getZookeeperAddressesList() - Method in class alluxio.grpc.MasterInfo.Builder
-
Empty means zookeeper is not enabled
- getZookeeperAddressesList() - Method in class alluxio.grpc.MasterInfo
-
Empty means zookeeper is not enabled
- getZookeeperAddressesList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
Empty means zookeeper is not enabled
- GLOBAL - Static variable in class alluxio.client.quota.CacheScope
-
- global() - Static method in class alluxio.conf.Configuration
-
- global() - Static method in class alluxio.security.user.ServerUserState
-
- GLOBAL_RATE_LIMITER_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.ProxyWebServer
-
- GraceMode - Enum in alluxio.master
-
Defines the grace mode of exclusive locking of the state-lock.
- Graph - Class in alluxio.stress.graph
-
A representation of a graph.
- Graph() - Constructor for class alluxio.stress.graph.Graph
-
- graphGenerator() - Method in class alluxio.stress.client.ClientIOSummary
-
- GraphGenerator() - Constructor for class alluxio.stress.client.ClientIOSummary.GraphGenerator
-
- graphGenerator() - Method in class alluxio.stress.client.ClientIOTaskResult
-
- GraphGenerator() - Constructor for class alluxio.stress.client.ClientIOTaskResult.GraphGenerator
-
- GraphGenerator - Class in alluxio.stress
-
This generates graphs from a list of summaries.
- GraphGenerator() - Constructor for class alluxio.stress.GraphGenerator
-
- graphGenerator() - Method in interface alluxio.stress.Summary
-
- graphGenerator() - Method in class alluxio.stress.worker.IOTaskSummary
-
- GraphGenerator() - Constructor for class alluxio.stress.worker.IOTaskSummary.GraphGenerator
-
- graphGenerator() - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- GraphGenerator() - Constructor for class alluxio.stress.worker.WorkerBenchSummary.GraphGenerator
-
- GraphiteSink - Class in alluxio.metrics.sink
-
A sink which publishes metric values to a Graphite server.
- GraphiteSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.GraphiteSink
-
- GROUP_COMPONENT - Static variable in enum alluxio.security.authorization.AclEntryType
-
- GROUP_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
-
- GROUP_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
-
- GROUP_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsStatus
-
- GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
- GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
-
- GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
-
- GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
-
- GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
-
- GROUPACTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
-
- GROUPBITS_FIELD_NUMBER - Static variable in class alluxio.grpc.PMode
-
- GroupMappingService - Interface in alluxio.security.group
-
Interface for Alluxio user-to-groups mapping.
- GroupMappingService.Factory - Class in alluxio.security.group
-
Factory for creating a new instance.
- GRPC_REFLECTION_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- GRPC_REFLECTION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- GrpcBlockingStream<ReqT,ResT> - Class in alluxio.client.block.stream
-
A helper class for accessing gRPC bi-directional stream synchronously.
- GrpcBlockingStream(Function<StreamObserver<ResT>, StreamObserver<ReqT>>, int, String) - Constructor for class alluxio.client.block.stream.GrpcBlockingStream
-
- GrpcCallTracker - Class in alluxio.master.file.contexts
-
- GrpcCallTracker(StreamObserver<?>) - Constructor for class alluxio.master.file.contexts.GrpcCallTracker
-
Creates a call tracker for gRPC.
- GrpcChannel - Class in alluxio.grpc
-
Used to gather gRPC level resources and indexes together.
- GrpcChannel(GrpcChannelKey, ManagedChannel) - Constructor for class alluxio.grpc.GrpcChannel
-
Creates a new connection object.
- GrpcChannelBuilder - Class in alluxio.grpc
-
A gRPC channel builder that authenticates with
GrpcServer
at the target during channel
building.
- GrpcChannelBuilder(GrpcServerAddress, AlluxioConfiguration, AuthType, boolean) - Constructor for class alluxio.grpc.GrpcChannelBuilder
-
- GrpcChannelKey - Class in alluxio.grpc
-
- GrpcChannelKey(GrpcNetworkGroup, GrpcServerAddress, int) - Constructor for class alluxio.grpc.GrpcChannelKey
-
Constructor.
- GrpcChannelPool - Class in alluxio.grpc
-
Used to provide gRPC level connection management and pooling facilities.
- GrpcDataMessageBlockingStream<ReqT,ResT> - Class in alluxio.client.block.stream
-
A helper class for accessing gRPC bi-directional stream synchronously.
- GrpcDataMessageBlockingStream(Function<StreamObserver<ResT>, StreamObserver<ReqT>>, int, String, DataMessageMarshaller<ReqT>, DataMessageMarshaller<ResT>) - Constructor for class alluxio.client.block.stream.GrpcDataMessageBlockingStream
-
- GrpcDataReader - Class in alluxio.client.block.stream
-
A gRPC data reader that streams a region from gRPC data server.
- GrpcDataReader.Factory - Class in alluxio.client.block.stream
-
- GrpcDataServer - Class in alluxio.worker.grpc
-
Runs a gRPC data server that responds to block requests.
- GrpcDataServer(String, SocketAddress, BlockWorkerGrpc.BlockWorkerImplBase) - Constructor for class alluxio.worker.grpc.GrpcDataServer
-
- GrpcDataWriter - Class in alluxio.client.block.stream
-
A gRPC data writer that streams a full block or a UFS file to a gRPC data server.
- GrpcExceptionUtils - Class in alluxio.grpc
-
Utility methods for conversion between alluxio and grpc status exceptions.
- GrpcExceptionUtils() - Constructor for class alluxio.grpc.GrpcExceptionUtils
-
- GrpcExecutors - Class in alluxio.worker.grpc
-
Executors for gRPC block server.
- GrpcMessagingClient - Class in alluxio.master.transport
-
Client implementation based on Alluxio gRPC messaging.
- GrpcMessagingClient(AlluxioConfiguration, UserState, ExecutorService) - Constructor for class alluxio.master.transport.GrpcMessagingClient
-
Creates messaging client that can be used to connect to remote messaging servers.
- GrpcMessagingClientConnection - Class in alluxio.master.transport
-
- GrpcMessagingClientConnection(GrpcMessagingContext, ExecutorService, GrpcChannel, long) - Constructor for class alluxio.master.transport.GrpcMessagingClientConnection
-
Creates a messaging connection for client.
- GrpcMessagingConnection - Class in alluxio.master.transport
-
- GrpcMessagingConnection(GrpcMessagingConnection.ConnectionOwner, String, GrpcMessagingContext, ExecutorService, long) - Constructor for class alluxio.master.transport.GrpcMessagingConnection
-
Creates a connection object.
- GrpcMessagingConnection.ConnectionOwner - Enum in alluxio.master.transport
-
Defines the owner of connection.
- GrpcMessagingConnection.ContextualFuture<T> - Class in alluxio.master.transport
-
A future with catalyst thread context.
- GrpcMessagingConnection.HandlerHolder - Class in alluxio.master.transport
-
Holds message handler and catalyst thread context.
- GrpcMessagingContext - Class in alluxio.master.transport
-
The context for Grpc messaging single thread.
- GrpcMessagingContext(String, Serializer) - Constructor for class alluxio.master.transport.GrpcMessagingContext
-
- GrpcMessagingContext(GrpcMessagingThreadFactory, Serializer) - Constructor for class alluxio.master.transport.GrpcMessagingContext
-
- GrpcMessagingContext(ScheduledExecutorService, Serializer) - Constructor for class alluxio.master.transport.GrpcMessagingContext
-
- GrpcMessagingContext(Thread, ScheduledExecutorService, Serializer) - Constructor for class alluxio.master.transport.GrpcMessagingContext
-
- GrpcMessagingProxy - Class in alluxio.master.transport
-
Used to provide external proxy configuration to messaging servers/clients.
- GrpcMessagingProxy() - Constructor for class alluxio.master.transport.GrpcMessagingProxy
-
Creates new proxy configuration.
- GrpcMessagingServer - Class in alluxio.master.transport
-
Server implementation based on Alluxio gRPC messaging.
- GrpcMessagingServer(AlluxioConfiguration, UserState, ExecutorService, GrpcMessagingProxy) - Constructor for class alluxio.master.transport.GrpcMessagingServer
-
Creates a transport server that can be used to accept connections from remote clients.
- GrpcMessagingServerConnection - Class in alluxio.master.transport
-
- GrpcMessagingServerConnection(String, GrpcMessagingContext, ExecutorService, long) - Constructor for class alluxio.master.transport.GrpcMessagingServerConnection
-
Creates a messaging connection for server.
- GrpcMessagingServiceClientHandler - Class in alluxio.master.transport
-
gRPC service handler for message exchange between messaging clients and servers
that are created by
GrpcMessagingTransport
.
- GrpcMessagingServiceClientHandler(InetSocketAddress, Consumer<GrpcMessagingConnection>, GrpcMessagingContext, ExecutorService, long) - Constructor for class alluxio.master.transport.GrpcMessagingServiceClientHandler
-
- GrpcMessagingThread - Class in alluxio.master.transport
-
- GrpcMessagingThread(Runnable, String) - Constructor for class alluxio.master.transport.GrpcMessagingThread
-
- GrpcMessagingThreadFactory - Class in alluxio.master.transport
-
- GrpcMessagingThreadFactory(String) - Constructor for class alluxio.master.transport.GrpcMessagingThreadFactory
-
- GrpcMessagingTransport - Class in alluxio.master.transport
-
Transport implementation based on Alluxio gRPC messaging.
- GrpcMessagingTransport(AlluxioConfiguration, UserState, String) - Constructor for class alluxio.master.transport.GrpcMessagingTransport
-
- GrpcMessagingTransport(AlluxioConfiguration, AlluxioConfiguration, UserState, UserState, String) - Constructor for class alluxio.master.transport.GrpcMessagingTransport
-
- GrpcNetworkGroup - Enum in alluxio.grpc
-
Used to define connection level multiplexing groups.
- GrpcSerializationUtils - Class in alluxio.grpc
-
Utilities for gRPC message serialization.
- GrpcSerializationUtils() - Constructor for class alluxio.grpc.GrpcSerializationUtils
-
- GrpcServer - Class in alluxio.grpc
-
An authenticated gRPC server.
- GrpcServer(Server, AuthenticationServer, Closer, long) - Constructor for class alluxio.grpc.GrpcServer
-
- GrpcServerAddress - Class in alluxio.grpc
-
Defines an gRPC server endpoint.
- GrpcServerBuilder - Class in alluxio.grpc
-
Provides authenticated gRPC server creation.
- GrpcServerModule - Class in alluxio.worker.modules
-
Grpc worker module.
- GrpcServerModule() - Constructor for class alluxio.worker.modules.GrpcServerModule
-
- GrpcService - Class in alluxio.grpc
-
Utility class for wrapping gRPC service definition.
- GrpcService(BindableService) - Constructor for class alluxio.grpc.GrpcService
-
- GrpcService(ServerServiceDefinition) - Constructor for class alluxio.grpc.GrpcService
-
- GrpcUtils - Class in alluxio.grpc
-
Utility methods for conversion between wire types and grpc types.
- GzipMarshaller - Class in alluxio.util.compression
-
- GzipMarshaller() - Constructor for class alluxio.util.compression.GzipMarshaller
-
- HADOOP_AUTH_METHOD - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- HADOOP_CONF_DIR_ENV_VAR - Static variable in class alluxio.cli.hdfs.HdfsConfParityValidationTask
-
Name of the environment variable to store the path to Hadoop config directory.
- HADOOP_CONF_DIR_OPTION - Static variable in class alluxio.cli.hdfs.HdfsConfParityValidationTask
-
- HADOOP_KERBEROS_KEYTAB_LOGIN_AUTORENEWAL - Static variable in class alluxio.conf.PropertyKey
-
- HADOOP_KERBEROS_KEYTAB_LOGIN_AUTORENEWAL - Static variable in class alluxio.conf.PropertyKey.Name
-
- HADOOP_KRB5_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
-
- HADOOP_KRB5_CONF_KEY_FILE - Static variable in class alluxio.conf.PropertyKey.Name
-
- HADOOP_PREFIX - Static variable in class alluxio.cli.hdfs.HdfsVersionValidationTask
-
- HADOOP_SECURITY_AUTHENTICATION - Static variable in class alluxio.conf.PropertyKey
-
- HADOOP_SECURITY_AUTHENTICATION - Static variable in class alluxio.conf.PropertyKey.Name
-
- HADOOP_VERSION - Static variable in class alluxio.ProjectConstants
-
- HadoopBenchThreadState() - Constructor for class alluxio.fsmaster.FileSystemBench.HadoopBenchThreadState
-
- HadoopConfigurationFileParser - Class in alluxio.cli.hdfs
-
Parser for configuration files.
- HadoopConfigurationFileParser() - Constructor for class alluxio.cli.hdfs.HadoopConfigurationFileParser
-
- HadoopConfigurationUtils - Class in alluxio.hadoop
-
- HadoopFileOpener - Interface in alluxio.hadoop
-
Interface to wrap open method of file system.
- hadoopGetFileStatusBench(Blackhole, FileSystemBench.HadoopBenchThreadState) - Method in class alluxio.fsmaster.FileSystemBench
-
- HadoopUtils - Class in alluxio.hadoop
-
Utility class for using Alluxio with Hadoop.
- handle(BiFunction<? super T, Throwable, ? extends U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
- handle(BiFunction<? super T, Throwable, ? extends U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
-
Returns a new CompletionStage that, when this stage completes either normally or exceptionally,
is executed with this stage's result and exception as arguments to the supplied function.
- handle(Signal) - Method in class alluxio.fuse.FuseSignalHandler
-
- handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler
-
Process s3 multipart upload request.
- handle(Callback[]) - Method in class alluxio.security.authentication.plain.PlainSaslClientCallbackHandler
-
- handle(Callback[]) - Method in class alluxio.security.authentication.plain.PlainSaslServerCallbackHandler
-
- handle(Callback[]) - Method in class alluxio.security.login.AppLoginModule.AppCallbackHandler
-
- handleAsync(BiFunction<? super T, Throwable, ? extends U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
- handleAsync(BiFunction<? super T, Throwable, ? extends U>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
- handleAsync(BiFunction<? super T, Throwable, ? extends U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
-
Returns a new CompletionStage that, when this stage completes either normally or exceptionally,
is executed using this stage's default asynchronous execution facility, with this stage's
result and exception as arguments to the supplied function.
- handleAsync(BiFunction<? super T, Throwable, ? extends U>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
-
Returns a new CompletionStage that, when this stage completes either normally or exceptionally,
is executed using the supplied executor, with this stage's result and exception as arguments to
the supplied function.
- handleContent(HttpContent) - Method in class alluxio.worker.s3.S3NettyBaseTask
-
Run core S3 API logic with HttpContent in different S3 task.
- handleJournalReplayFailure(Logger, Throwable, String, Object...) - Static method in class alluxio.master.journal.JournalUtils
-
Logs a fatal error and exits the system if required.
- handleMessage(SaslMessage) - Method in class alluxio.security.authentication.AbstractSaslClientHandler
-
- handleMessage(SaslMessage) - Method in class alluxio.security.authentication.AbstractSaslServerHandler
-
- handleMessage(SaslMessage) - Method in interface alluxio.security.authentication.SaslClientHandler
-
- handleMessage(SaslMessage) - Method in interface alluxio.security.authentication.SaslServerHandler
-
- handleNodeDelete(Address) - Method in class alluxio.master.meta.checkconf.ConfigurationStore
-
Updates configuration when a node delete.
- handleNodeLost(Address) - Method in class alluxio.master.meta.checkconf.ConfigurationStore
-
Updates configuration when a live node becomes lost.
- handler(Class<T>, Consumer<T>) - Method in class alluxio.master.transport.GrpcMessagingConnection
-
Registers a new message handler.
- handler(Class<T>, Function<T, CompletableFuture<U>>) - Method in class alluxio.master.transport.GrpcMessagingConnection
-
Registers a new message handler.
- handleResponseMessage(TransportMessage) - Method in class alluxio.master.transport.GrpcMessagingConnection
-
- handleTaskAsync() - Method in class alluxio.proxy.s3.S3BaseTask
-
Run S3 API logic in a customized async way, e.g.
- handleTaskAsync() - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
-
- handleTaskAsync() - Method in class alluxio.worker.s3.S3NettyBaseTask
-
Run S3 API logic in a customized async way, e.g.
- HAS_DIRECT_CHILDREN_LOADED_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
-
- hasAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- hasAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- hasAccessAcl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- hasAccessMode() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.Bits accessMode = 3;
- hasAccessMode() - Method in class alluxio.grpc.GetStatusPOptions
-
optional .alluxio.grpc.Bits accessMode = 3;
- hasAccessMode() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional .alluxio.grpc.Bits accessMode = 3;
- hasAcl() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl acl = 27;
- hasAcl() - Method in class alluxio.grpc.FileInfo
-
optional .alluxio.grpc.file.PAcl acl = 27;
- hasAcl() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional .alluxio.grpc.file.PAcl acl = 27;
- hasAcl() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- hasAcl() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- hasAcl() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- hasAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- hasAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- hasAcl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- hasAcl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- hasAcl() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- hasAcl() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- hasAcl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- hasAcl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- hasAcl() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- hasAction() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the set action to perform
- hasAction() - Method in class alluxio.grpc.SetAclPRequest
-
the set action to perform
- hasAction() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the set action to perform
- hasAction() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional .alluxio.proto.journal.PSetAclAction action = 3;
- hasAction() - Method in class alluxio.proto.journal.File.SetAclEntry
-
optional .alluxio.proto.journal.PSetAclAction action = 3;
- hasAction() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
optional .alluxio.proto.journal.PSetAclAction action = 3;
- hasActionId() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionId = 1;
- hasActionId() - Method in class alluxio.grpc.ActionInfo
-
optional string actionId = 1;
- hasActionId() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string actionId = 1;
- hasActionId() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string actionId = 2;
- hasActionId() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional string actionId = 2;
- hasActionId() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional string actionId = 2;
- hasActions() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional .alluxio.proto.shared.AclActions actions = 2;
- hasActions() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
optional .alluxio.proto.shared.AclActions actions = 2;
- hasActions() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
-
optional .alluxio.proto.shared.AclActions actions = 2;
- hasActionsCanceled() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsCanceled = 8;
- hasActionsCanceled() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 actionsCanceled = 8;
- hasActionsCanceled() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 actionsCanceled = 8;
- hasActionsFailed() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsFailed = 9;
- hasActionsFailed() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 actionsFailed = 9;
- hasActionsFailed() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 actionsFailed = 9;
- hasActionsRunning() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsRunning = 6;
- hasActionsRunning() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 actionsRunning = 6;
- hasActionsRunning() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 actionsRunning = 6;
- hasActionsScheduled() - Method in class alluxio.grpc.PolicyStatus.Builder
-
metrics
- hasActionsScheduled() - Method in class alluxio.grpc.PolicyStatus
-
metrics
- hasActionsScheduled() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
metrics
- hasActionsSucceeded() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsSucceeded = 7;
- hasActionsSucceeded() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 actionsSucceeded = 7;
- hasActionsSucceeded() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 actionsSucceeded = 7;
- hasActionStatus() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionStatus = 3;
- hasActionStatus() - Method in class alluxio.grpc.ActionInfo
-
optional string actionStatus = 3;
- hasActionStatus() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string actionStatus = 3;
- hasActionType() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionType = 2;
- hasActionType() - Method in class alluxio.grpc.ActionInfo
-
optional string actionType = 2;
- hasActionType() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string actionType = 2;
- hasActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
action fields.
- hasActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
action fields.
- hasActiveSyncTxId() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
action fields.
- hasAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- hasAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- hasAddMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- hasAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- hasAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- hasAddQuorumServerRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- hasAddress() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.NetAddress address = 1;
- hasAddress() - Method in class alluxio.grpc.ProxyStatus
-
optional .alluxio.grpc.NetAddress address = 1;
- hasAddress() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional .alluxio.grpc.NetAddress address = 1;
- hasAddress() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- hasAddress() - Method in class alluxio.grpc.WorkerInfo
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- hasAddress() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- hasAddress() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- hasAddress() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- hasAddress() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- hasAddresses() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional .alluxio.grpc.NetAddress addresses = 1;
- hasAddresses() - Method in class alluxio.grpc.MasterVersion
-
optional .alluxio.grpc.NetAddress addresses = 1;
- hasAddresses() - Method in interface alluxio.grpc.MasterVersionOrBuilder
-
optional .alluxio.grpc.NetAddress addresses = 1;
- hasAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- hasAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- hasAddSyncPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- hasAll() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
optional bool all = 1;
- hasAll() - Method in class alluxio.grpc.table.AllOrNoneSet
-
optional bool all = 1;
- hasAll() - Method in interface alluxio.grpc.table.AllOrNoneSetOrBuilder
-
optional bool all = 1;
- hasAllOrNone() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- hasAllOrNone() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- hasAllOrNone() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- hasAllowed() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional bool allowed = 2;
- hasAllowed() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
optional bool allowed = 2;
- hasAllowed() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
-
optional bool allowed = 2;
- hasAllowedOnStandbyMasters() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
optional bool allowedOnStandbyMasters = 2;
- hasAllowedOnStandbyMasters() - Method in class alluxio.grpc.GetServiceVersionPRequest
-
optional bool allowedOnStandbyMasters = 2;
- hasAllowedOnStandbyMasters() - Method in interface alluxio.grpc.GetServiceVersionPRequestOrBuilder
-
optional bool allowedOnStandbyMasters = 2;
- hasAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool allowExists = 2;
- hasAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional bool allowExists = 2;
- hasAllowExists() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional bool allowExists = 2;
- hasAllowLeader() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool allowLeader = 3;
- hasAllowLeader() - Method in class alluxio.grpc.BackupPOptions
-
optional bool allowLeader = 3;
- hasAllowLeader() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
-
optional bool allowLeader = 3;
- hasAlluxioOnly() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool alluxioOnly = 2;
- hasAlluxioOnly() - Method in class alluxio.grpc.DeletePOptions
-
optional bool alluxioOnly = 2;
- hasAlluxioOnly() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional bool alluxioOnly = 2;
- hasAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
Deprecated, this field is about whether to delete in the UFS.
- hasAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
Deprecated, this field is about whether to delete in the UFS.
- hasAlluxioOnly() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
Deprecated, this field is about whether to delete in the UFS.
- hasAlluxioPath() - Method in class alluxio.grpc.File.Builder
-
optional string alluxio_path = 1;
- hasAlluxioPath() - Method in class alluxio.grpc.File
-
optional string alluxio_path = 1;
- hasAlluxioPath() - Method in interface alluxio.grpc.FileOrBuilder
-
optional string alluxio_path = 1;
- hasAlluxioPath() - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of alluxio mount point
- hasAlluxioPath() - Method in class alluxio.grpc.MountPRequest
-
the path of alluxio mount point
- hasAlluxioPath() - Method in interface alluxio.grpc.MountPRequestOrBuilder
-
the path of alluxio mount point
- hasAlluxioPath() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
optional string alluxioPath = 1;
- hasAlluxioPath() - Method in class alluxio.grpc.ReverseResolvePResponse
-
optional string alluxioPath = 1;
- hasAlluxioPath() - Method in interface alluxio.grpc.ReverseResolvePResponseOrBuilder
-
optional string alluxioPath = 1;
- hasAlluxioPath() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
the path of the alluxio mount point
- hasAlluxioPath() - Method in class alluxio.grpc.UnmountPRequest
-
the path of the alluxio mount point
- hasAlluxioPath() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
-
the path of the alluxio mount point
- hasAlluxioPath() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
the path of alluxio mount point
- hasAlluxioPath() - Method in class alluxio.grpc.UpdateMountPRequest
-
the path of alluxio mount point
- hasAlluxioPath() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
-
the path of alluxio mount point
- hasAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string alluxio_path = 1;
- hasAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional string alluxio_path = 1;
- hasAlluxioPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional string alluxio_path = 1;
- hasAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
optional string alluxio_path = 1;
- hasAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
-
optional string alluxio_path = 1;
- hasAlluxioPath() - Method in interface alluxio.proto.journal.File.DeleteMountPointEntryOrBuilder
-
optional string alluxio_path = 1;
- hasAlluxioVersion() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional string alluxioVersion = 3;
- hasAlluxioVersion() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
optional string alluxioVersion = 3;
- hasAlluxioVersion() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
-
optional string alluxioVersion = 3;
- hasAnnotation(PropertyKey) - Method in class alluxio.conf.DeprecatedKeyChecker
-
Returns whether or not the given property key is marked by this class' annotation.
- hasAsync() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional bool async = 6;
- hasAsync() - Method in class alluxio.grpc.CacheRequest
-
optional bool async = 6;
- hasAsync() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional bool async = 6;
- hasAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- hasAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- hasAsyncPersistOptions() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- hasAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- hasAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- hasAsyncPersistRequest() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- hasAuthenticationScheme() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
- hasAuthenticationScheme() - Method in class alluxio.grpc.SaslMessage
-
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
- hasAuthenticationScheme() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
- hasAuthority() - Method in class alluxio.AlluxioURI
-
- hasAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional double avg_col_len = 2;
- hasAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
optional double avg_col_len = 2;
- hasAvgColLen() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
-
optional double avg_col_len = 2;
- hasAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional double avg_col_len = 2;
- hasAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional double avg_col_len = 2;
- hasAvgColLen() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional double avg_col_len = 2;
- hasBackupError() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional bytes backupError = 6;
- hasBackupError() - Method in class alluxio.grpc.BackupPStatus
-
optional bytes backupError = 6;
- hasBackupError() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional bytes backupError = 6;
- hasBackupHost() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupHost = 3;
- hasBackupHost() - Method in class alluxio.grpc.BackupPStatus
-
optional string backupHost = 3;
- hasBackupHost() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional string backupHost = 3;
- hasBackupId() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupId = 1;
- hasBackupId() - Method in class alluxio.grpc.BackupPStatus
-
optional string backupId = 1;
- hasBackupId() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional string backupId = 1;
- hasBackupId() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
optional string backupId = 1;
- hasBackupId() - Method in class alluxio.grpc.BackupStatusPRequest
-
optional string backupId = 1;
- hasBackupId() - Method in interface alluxio.grpc.BackupStatusPRequestOrBuilder
-
optional string backupId = 1;
- hasBackupState() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional .alluxio.grpc.meta.BackupState backupState = 2;
- hasBackupState() - Method in class alluxio.grpc.BackupPStatus
-
optional .alluxio.grpc.meta.BackupState backupState = 2;
- hasBackupState() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional .alluxio.grpc.meta.BackupState backupState = 2;
- hasBackupUri() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupUri = 4;
- hasBackupUri() - Method in class alluxio.grpc.BackupPStatus
-
optional string backupUri = 4;
- hasBackupUri() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional string backupUri = 4;
- hasBandwidth() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional int64 bandwidth = 1;
- hasBandwidth() - Method in class alluxio.grpc.CopyJobPOptions
-
optional int64 bandwidth = 1;
- hasBandwidth() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional int64 bandwidth = 1;
- hasBandwidth() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional int64 bandwidth = 1;
- hasBandwidth() - Method in class alluxio.grpc.LoadJobPOptions
-
optional int64 bandwidth = 1;
- hasBandwidth() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
-
optional int64 bandwidth = 1;
- hasBandwidth() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional int64 bandwidth = 1;
- hasBandwidth() - Method in class alluxio.grpc.MoveJobPOptions
-
optional int64 bandwidth = 1;
- hasBandwidth() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional int64 bandwidth = 1;
- hasBandwidth() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
optional int64 bandwidth = 3;
- hasBandwidth() - Method in class alluxio.grpc.UfsReadOptions
-
optional int64 bandwidth = 3;
- hasBandwidth() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
-
optional int64 bandwidth = 3;
- hasBandwidth() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional int64 bandwidth = 4;
- hasBandwidth() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional int64 bandwidth = 4;
- hasBandwidth() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional int64 bandwidth = 4;
- hasBandwidth() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional int64 bandwidth = 3;
- hasBandwidth() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional int64 bandwidth = 3;
- hasBandwidth() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional int64 bandwidth = 3;
- hasBandwidth() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional int64 bandwidth = 4;
- hasBandwidth() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional int64 bandwidth = 4;
- hasBandwidth() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional int64 bandwidth = 4;
- hasBaseLayout() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- hasBaseLayout() - Method in class alluxio.grpc.table.Partition
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- hasBaseLayout() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- hasBatchSize() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Batch size for partial listings.
- hasBatchSize() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Batch size for partial listings.
- hasBatchSize() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Batch size for partial listings.
- hasBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- hasBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- hasBinaryStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- hasBits() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.Bits bits = 1;
- hasBits() - Method in class alluxio.grpc.CheckAccessPOptions
-
optional .alluxio.grpc.Bits bits = 1;
- hasBits() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
-
optional .alluxio.grpc.Bits bits = 1;
- hasBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional string bit_vectors = 4;
- hasBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
optional string bit_vectors = 4;
- hasBitVectors() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
-
optional string bit_vectors = 4;
- hasBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional string bit_vectors = 4;
- hasBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
optional string bit_vectors = 4;
- hasBitVectors() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
-
optional string bit_vectors = 4;
- hasBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional string bit_vectors = 5;
- hasBitVectors() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional string bit_vectors = 5;
- hasBlock() - Method in class alluxio.grpc.BlockStatus.Builder
-
required .alluxio.grpc.block.Block block = 1;
- hasBlock() - Method in class alluxio.grpc.BlockStatus
-
required .alluxio.grpc.block.Block block = 1;
- hasBlock() - Method in interface alluxio.grpc.BlockStatusOrBuilder
-
required .alluxio.grpc.block.Block block = 1;
- hasBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- hasBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- hasBlockContainerIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- hasBlockCount() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
- hasBlockCount() - Method in class alluxio.grpc.GetRegisterLeasePRequest
-
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
- hasBlockCount() - Method in interface alluxio.grpc.GetRegisterLeasePRequestOrBuilder
-
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
- hasBlockId() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.AsyncCacheRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.Block.Builder
-
required int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.Block
-
required int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.BlockInfo.Builder
-
optional int64 blockId = 1;
- hasBlockId() - Method in class alluxio.grpc.BlockInfo
-
optional int64 blockId = 1;
- hasBlockId() - Method in interface alluxio.grpc.BlockInfoOrBuilder
-
optional int64 blockId = 1;
- hasBlockId() - Method in interface alluxio.grpc.BlockOrBuilder
-
required int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.CacheRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the id of the block being committed
- hasBlockId() - Method in class alluxio.grpc.CommitBlockPRequest
-
the id of the block being committed
- hasBlockId() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the id of the block being committed
- hasBlockId() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
the id of the block
- hasBlockId() - Method in class alluxio.grpc.GetBlockInfoPRequest
-
the id of the block
- hasBlockId() - Method in interface alluxio.grpc.GetBlockInfoPRequestOrBuilder
-
the id of the block
- hasBlockId() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.MoveBlockRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.grpc.MoveBlockRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.ReadRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.grpc.RemoveBlockRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.grpc.RemoveBlockRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCloseRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
optional int64 block_id = 1;
- hasBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
-
optional int64 block_id = 1;
- hasBlockId() - Method in interface alluxio.proto.journal.Block.DeleteBlockEntryOrBuilder
-
optional int64 block_id = 1;
- hasBlockInfo() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- hasBlockInfo() - Method in class alluxio.grpc.FileBlockInfo
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- hasBlockInfo() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- hasBlockInfo() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- hasBlockInfo() - Method in class alluxio.grpc.GetBlockInfoPResponse
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- hasBlockInfo() - Method in interface alluxio.grpc.GetBlockInfoPResponseOrBuilder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- hasBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- hasBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- hasBlockInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- hasBlockLocation() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- hasBlockLocation() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- hasBlockLocation() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- hasBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- hasBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- hasBlockMasterInfo() - Method in interface alluxio.grpc.GetBlockMasterInfoPResponseOrBuilder
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- hasBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
-
Checks if the storage has a given block.
- hasBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
-
Checks if a block is in this storage dir.
- hasBlockSize() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional int64 block_size = 3;
- hasBlockSize() - Method in class alluxio.grpc.UfsFileStatus
-
optional int64 block_size = 3;
- hasBlockSize() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
-
optional int64 block_size = 3;
- hasBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The block size.
- hasBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
The block size.
- hasBlockSize() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
The block size.
- hasBlockSizeBytes() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int64 blockSizeBytes = 1;
- hasBlockSizeBytes() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int64 blockSizeBytes = 1;
- hasBlockSizeBytes() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int64 blockSizeBytes = 1;
- hasBlockSizeBytes() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 blockSizeBytes = 6;
- hasBlockSizeBytes() - Method in class alluxio.grpc.FileInfo
-
optional int64 blockSizeBytes = 6;
- hasBlockSizeBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 blockSizeBytes = 6;
- hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 block_size_bytes = 8;
- hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 block_size_bytes = 8;
- hasBlockSizeBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 block_size_bytes = 8;
- hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 block_size_bytes = 2;
- hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int64 block_size_bytes = 2;
- hasBlockSizeBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int64 block_size_bytes = 2;
- hasBlockSizeBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
file only
- hasBlockSizeBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
file only
- hasBlockSizeBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
file only
- hasBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- hasBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- hasBooleanStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- hasBooleanType() - Method in class alluxio.grpc.table.Value.Builder
-
bool boolean_type = 4;
- hasBooleanType() - Method in class alluxio.grpc.table.Value
-
bool boolean_type = 4;
- hasBooleanType() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
bool boolean_type = 4;
- hasBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
optional int64 bucket_count = 2;
- hasBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
optional int64 bucket_count = 2;
- hasBucketCount() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
-
optional int64 bucket_count = 2;
- hasBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- hasBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- hasBucketProperty() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- hasBuildVersion() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
the worker version to display in info pages (useful for rolling upgrades)
- hasBuildVersion() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
the worker version to display in info pages (useful for rolling upgrades)
- hasBuildVersion() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
-
the worker version to display in info pages (useful for rolling upgrades)
- hasBuildVersion() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- hasBuildVersion() - Method in class alluxio.grpc.WorkerInfo
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- hasBuildVersion() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- hasBypassDelegation() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool bypassDelegation = 4;
- hasBypassDelegation() - Method in class alluxio.grpc.BackupPOptions
-
optional bool bypassDelegation = 4;
- hasBypassDelegation() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
-
optional bool bypassDelegation = 4;
- hasBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
optional int64 bytes = 1;
- hasBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse
-
optional int64 bytes = 1;
- hasBytes() - Method in interface alluxio.grpc.GetCapacityBytesPResponseOrBuilder
-
optional int64 bytes = 1;
- hasBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
optional int64 bytes = 1;
- hasBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse
-
optional int64 bytes = 1;
- hasBytes() - Method in interface alluxio.grpc.GetUsedBytesPResponseOrBuilder
-
optional int64 bytes = 1;
- hasBytesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
optional int64 bytes_skipped = 4;
- hasBytesSkipped() - Method in class alluxio.grpc.LoadFileResponse
-
optional int64 bytes_skipped = 4;
- hasBytesSkipped() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
optional int64 bytes_skipped = 4;
- hasCacheable() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool cacheable = 11;
- hasCacheable() - Method in class alluxio.grpc.FileInfo
-
optional bool cacheable = 11;
- hasCacheable() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool cacheable = 11;
- hasCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool cacheable = 11;
- hasCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional bool cacheable = 11;
- hasCacheable() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional bool cacheable = 11;
- hasCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional bool cacheable = 5;
- hasCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional bool cacheable = 5;
- hasCacheable() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional bool cacheable = 5;
- hasCacheSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional int64 cacheSize = 2;
- hasCacheSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
optional int64 cacheSize = 2;
- hasCacheSize() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
-
optional int64 cacheSize = 2;
- hasCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
optional bool cancel = 2;
- hasCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
optional bool cancel = 2;
- hasCancel() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
-
optional bool cancel = 2;
- hasCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
If set, this request is to cancel the reading request for the id.
- hasCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
If set, this request is to cancel the reading request for the id.
- hasCancel() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
If set, this request is to cancel the reading request for the id.
- hasCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional bool cancel = 6;
- hasCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
optional bool cancel = 6;
- hasCancel() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
optional bool cancel = 6;
- hasCancelTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- hasCancelTaskCommand() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- hasCancelTaskCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- hasCanRegisterAgain() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
optional bool canRegisterAgain = 3;
- hasCanRegisterAgain() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
optional bool canRegisterAgain = 3;
- hasCanRegisterAgain() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
-
optional bool canRegisterAgain = 3;
- hasCapacityBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 capacityBytes = 1;
- hasCapacityBytes() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int64 capacityBytes = 1;
- hasCapacityBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int64 capacityBytes = 1;
- hasCapacityBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 capacityBytes = 5;
- hasCapacityBytes() - Method in class alluxio.grpc.WorkerInfo
-
optional int64 capacityBytes = 5;
- hasCapacityBytes() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional int64 capacityBytes = 5;
- hasChannelRef() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string channelRef = 5;
- hasChannelRef() - Method in class alluxio.grpc.SaslMessage
-
optional string channelRef = 5;
- hasChannelRef() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional string channelRef = 5;
- hasCheckContent() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool check_content = 6;
- hasCheckContent() - Method in class alluxio.grpc.CopyJobPOptions
-
optional bool check_content = 6;
- hasCheckContent() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional bool check_content = 6;
- hasCheckContent() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool check_content = 6;
- hasCheckContent() - Method in class alluxio.grpc.MoveJobPOptions
-
optional bool check_content = 6;
- hasCheckContent() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional bool check_content = 6;
- hasCheckContent() - Method in class alluxio.grpc.WriteOptions.Builder
-
optional bool check_content = 3;
- hasCheckContent() - Method in class alluxio.grpc.WriteOptions
-
optional bool check_content = 3;
- hasCheckContent() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
-
optional bool check_content = 3;
- hasCheckContent() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional bool check_content = 11;
- hasCheckContent() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional bool check_content = 11;
- hasCheckContent() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional bool check_content = 11;
- hasCheckContent() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional bool check_content = 11;
- hasCheckContent() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional bool check_content = 11;
- hasCheckContent() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional bool check_content = 11;
- hasCheckS3BucketPath() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool checkS3BucketPath = 8;
- hasCheckS3BucketPath() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional bool checkS3BucketPath = 8;
- hasCheckS3BucketPath() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional bool checkS3BucketPath = 8;
- hasCheckS3BucketPath() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool checkS3BucketPath = 14;
- hasCheckS3BucketPath() - Method in class alluxio.grpc.CreateFilePOptions
-
optional bool checkS3BucketPath = 14;
- hasCheckS3BucketPath() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional bool checkS3BucketPath = 14;
- hasCheckUfs() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
optional bool checkUfs = 1;
- hasCheckUfs() - Method in class alluxio.grpc.GetMountTablePRequest
-
optional bool checkUfs = 1;
- hasCheckUfs() - Method in interface alluxio.grpc.GetMountTablePRequestOrBuilder
-
optional bool checkUfs = 1;
- hasChildCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 child_count = 26;
- hasChildCount() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 child_count = 26;
- hasChildCount() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 child_count = 26;
- hasChildren(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.caching.CachingInodeStore
-
- hasChildren(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
-
- hasChildren(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
-
- hasChildren(InodeDirectoryView, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- hasChildren(InodeDirectoryView) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
-
- hasChildren(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- hasChunk() - Method in class alluxio.grpc.ReadResponse.Builder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- hasChunk() - Method in class alluxio.grpc.ReadResponse
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- hasChunk() - Method in interface alluxio.grpc.ReadResponseOrBuilder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- hasChunk() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional bytes chunk = 3;
- hasChunk() - Method in class alluxio.grpc.SnapshotData
-
optional bytes chunk = 3;
- hasChunk() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
optional bytes chunk = 3;
- hasChunk() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- hasChunk() - Method in class alluxio.grpc.WriteRequest
-
.alluxio.grpc.block.Chunk chunk = 2;
- hasChunk() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
.alluxio.grpc.block.Chunk chunk = 2;
- hasChunkSize() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 chunk_size = 5;
- hasChunkSize() - Method in class alluxio.grpc.ReadRequest
-
optional int64 chunk_size = 5;
- hasChunkSize() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
optional int64 chunk_size = 5;
- hasChunkSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
If set, the server should send packets in the specified packet size.
- hasChunkSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
If set, the server should send packets in the specified packet size.
- hasChunkSize() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
If set, the server should send packets in the specified packet size.
- hasClientId() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string clientId = 3;
- hasClientId() - Method in class alluxio.grpc.SaslMessage
-
optional string clientId = 3;
- hasClientId() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional string clientId = 3;
- hasClusterConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string clusterConfigHash = 1;
- hasClusterConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse
-
optional string clusterConfigHash = 1;
- hasClusterConfigHash() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
-
optional string clusterConfigHash = 1;
- hasClusterConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string clusterConfigHash = 3;
- hasClusterConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse
-
optional string clusterConfigHash = 3;
- hasClusterConfigHash() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
optional string clusterConfigHash = 3;
- hasClusterConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional int64 clusterConfigLastUpdateTime = 5;
- hasClusterConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse
-
optional int64 clusterConfigLastUpdateTime = 5;
- hasClusterConfigLastUpdateTime() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
optional int64 clusterConfigLastUpdateTime = 5;
- hasClusterId() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string clusterId = 11;
- hasClusterId() - Method in class alluxio.grpc.MasterInfo
-
optional string clusterId = 11;
- hasClusterId() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional string clusterId = 11;
- hasClusterId() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
optional string cluster_id = 1;
- hasClusterId() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
optional string cluster_id = 1;
- hasClusterId() - Method in interface alluxio.proto.journal.Meta.ClusterInfoEntryOrBuilder
-
optional string cluster_id = 1;
- hasClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- hasClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- hasClusterInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- hasCmdConfig() - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional bytes cmdConfig = 1;
- hasCmdConfig() - Method in class alluxio.grpc.SubmitRequest
-
optional bytes cmdConfig = 1;
- hasCmdConfig() - Method in interface alluxio.grpc.SubmitRequestOrBuilder
-
optional bytes cmdConfig = 1;
- hasCmdProgress() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- hasCmdProgress() - Method in class alluxio.grpc.CmdSummary
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- hasCmdProgress() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- hasCmdStatus() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
optional .alluxio.grpc.job.Status cmdStatus = 1;
- hasCmdStatus() - Method in class alluxio.grpc.GetCmdStatusResponse
-
optional .alluxio.grpc.job.Status cmdStatus = 1;
- hasCmdStatus() - Method in interface alluxio.grpc.GetCmdStatusResponseOrBuilder
-
optional .alluxio.grpc.job.Status cmdStatus = 1;
- hasCmdStatusBlock() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- hasCmdStatusBlock() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- hasCmdStatusBlock() - Method in interface alluxio.grpc.GetCmdStatusDetailedResponseOrBuilder
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- hasCode() - Method in class alluxio.grpc.BlockStatus.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in class alluxio.grpc.BlockStatus
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in interface alluxio.grpc.BlockStatusOrBuilder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in class alluxio.grpc.FileFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in class alluxio.grpc.FileFailure
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in interface alluxio.grpc.FileFailureOrBuilder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in class alluxio.grpc.LoadFileFailure
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in class alluxio.grpc.RouteFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in class alluxio.grpc.RouteFailure
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasCode() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- hasColName() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_name = 1;
- hasColName() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional string col_name = 1;
- hasColName() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional string col_name = 1;
- hasColType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_type = 2;
- hasColType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional string col_type = 2;
- hasColType() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional string col_type = 2;
- hasColumnName() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
required string column_name = 1;
- hasColumnName() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
-
required string column_name = 1;
- hasColumnName() - Method in interface alluxio.grpc.table.layout.hive.SortingColumnOrBuilder
-
required string column_name = 1;
- hasCommand() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
optional .alluxio.grpc.Command command = 1;
- hasCommand() - Method in class alluxio.grpc.BlockHeartbeatPResponse
-
optional .alluxio.grpc.Command command = 1;
- hasCommand() - Method in interface alluxio.grpc.BlockHeartbeatPResponseOrBuilder
-
optional .alluxio.grpc.Command command = 1;
- hasCommand() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- hasCommand() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- hasCommand() - Method in interface alluxio.grpc.FileSystemHeartbeatPResponseOrBuilder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- hasCommand() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
- hasCommand() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
-
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
- hasCommand() - Method in interface alluxio.grpc.JobMasterHeartbeatPResponseOrBuilder
-
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
- hasCommand() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
optional .alluxio.grpc.meta.MetaCommand command = 1;
- hasCommand() - Method in class alluxio.grpc.MasterHeartbeatPResponse
-
optional .alluxio.grpc.meta.MetaCommand command = 1;
- hasCommand() - Method in interface alluxio.grpc.MasterHeartbeatPResponseOrBuilder
-
optional .alluxio.grpc.meta.MetaCommand command = 1;
- hasCommand() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- hasCommand() - Method in class alluxio.grpc.WriteRequest
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- hasCommand() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- hasCommandOptions() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- hasCommandOptions() - Method in class alluxio.grpc.FileSystemCommand
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- hasCommandOptions() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- hasCommandType() - Method in class alluxio.grpc.Command.Builder
-
optional .alluxio.grpc.CommandType commandType = 1;
- hasCommandType() - Method in class alluxio.grpc.Command
-
optional .alluxio.grpc.CommandType commandType = 1;
- hasCommandType() - Method in interface alluxio.grpc.CommandOrBuilder
-
optional .alluxio.grpc.CommandType commandType = 1;
- hasCommandType() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.CommandType commandType = 1;
- hasCommandType() - Method in class alluxio.grpc.FileSystemCommand
-
optional .alluxio.grpc.CommandType commandType = 1;
- hasCommandType() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
-
optional .alluxio.grpc.CommandType commandType = 1;
- hasComment() - Method in class alluxio.grpc.table.Database.Builder
-
optional string comment = 7;
- hasComment() - Method in class alluxio.grpc.table.Database
-
optional string comment = 7;
- hasComment() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string comment = 7;
- hasComment() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string comment = 4;
- hasComment() - Method in class alluxio.grpc.table.FieldSchema
-
optional string comment = 4;
- hasComment() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional string comment = 4;
- hasCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- hasCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- hasCommonOptions() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- hasCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in interface alluxio.grpc.CheckConsistencyPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- hasCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- hasCommonOptions() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- hasCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- hasCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- hasCommonOptions() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- hasCommonOptions() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- hasCommonOptions() - Method in class alluxio.grpc.DeletePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- hasCommonOptions() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- hasCommonOptions() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- hasCommonOptions() - Method in class alluxio.grpc.ExistsPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- hasCommonOptions() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- hasCommonOptions() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in class alluxio.grpc.FreePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in interface alluxio.grpc.GetNewBlockIdForFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- hasCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- hasCommonOptions() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- hasCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- hasCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- hasCommonOptions() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- hasCommonOptions() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- hasCommonOptions() - Method in class alluxio.grpc.MountPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- hasCommonOptions() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- hasCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- hasCommonOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.RenamePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.SetAclPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- hasCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- hasCommonOptions() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- hasCommonOptions() - Method in class alluxio.grpc.UnmountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.grpc.UnmountPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in interface alluxio.grpc.UnmountPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- hasCommonOptions() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- hasCommonOptions() - Method in interface alluxio.proto.client.Cache.PRocksPageStoreOptionsOrBuilder
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- hasCompleted() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool completed = 8;
- hasCompleted() - Method in class alluxio.grpc.FileInfo
-
optional bool completed = 8;
- hasCompleted() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool completed = 8;
- hasCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool completed = 10;
- hasCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional bool completed = 10;
- hasCompleted() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional bool completed = 10;
- hasCompleted() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional bool completed = 4;
- hasCompleted() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional bool completed = 4;
- hasCompleted() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional bool completed = 4;
- hasCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- hasCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- hasCompleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- hasConstraint() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- hasConstraint() - Method in class alluxio.grpc.table.ReadTablePRequest
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- hasConstraint() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- hasContainerHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string containerHost = 7;
- hasContainerHost() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string containerHost = 7;
- hasContainerHost() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string containerHost = 7;
- hasContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
optional int64 container_id = 1;
- hasContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
optional int64 container_id = 1;
- hasContainerId() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
-
optional int64 container_id = 1;
- hasContentHash() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional string contentHash = 4;
- hasContentHash() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional string contentHash = 4;
- hasContentHash() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional string contentHash = 4;
- hasContentHash() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string contentHash = 34;
- hasContentHash() - Method in class alluxio.grpc.FileInfo
-
optional string contentHash = 34;
- hasContentHash() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string contentHash = 34;
- hasContentHash() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional string content_hash = 1;
- hasContentHash() - Method in class alluxio.grpc.UfsFileStatus
-
optional string content_hash = 1;
- hasContentHash() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
-
optional string content_hash = 1;
- hasContentHash() - Method in class alluxio.grpc.WriteResponse.Builder
-
Errors will be handled by standard gRPC stream APIs.
- hasContentHash() - Method in class alluxio.grpc.WriteResponse
-
Errors will be handled by standard gRPC stream APIs.
- hasContentHash() - Method in interface alluxio.grpc.WriteResponseOrBuilder
-
Errors will be handled by standard gRPC stream APIs.
- hasContentLength() - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional int64 content_length = 2;
- hasContentLength() - Method in class alluxio.grpc.UfsFileStatus
-
optional int64 content_length = 2;
- hasContentLength() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
-
optional int64 content_length = 2;
- hasCopyJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- hasCopyJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- hasCopyJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- hasCount() - Method in class alluxio.grpc.StatusSummary.Builder
-
optional int64 count = 2;
- hasCount() - Method in class alluxio.grpc.StatusSummary
-
optional int64 count = 2;
- hasCount() - Method in interface alluxio.grpc.StatusSummaryOrBuilder
-
optional int64 count = 2;
- hasCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional bool createAncestors = 2;
- hasCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional bool createAncestors = 2;
- hasCreateAncestors() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional bool createAncestors = 2;
- hasCreatedAt() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional int64 created_at = 3;
- hasCreatedAt() - Method in class alluxio.grpc.PolicyInfo
-
optional int64 created_at = 3;
- hasCreatedAt() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
-
optional int64 created_at = 3;
- hasCreatedAt() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional int64 created_at = 3;
- hasCreatedAt() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
optional int64 created_at = 3;
- hasCreatedAt() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
-
optional int64 created_at = 3;
- hasCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- hasCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- hasCreateUfsFileOptions() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- hasCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for ufs writes.
- hasCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
This is only applicable for ufs writes.
- hasCreateUfsFileOptions() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
This is only applicable for ufs writes.
- hasCreationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 creationTimeMs = 7;
- hasCreationTimeMs() - Method in class alluxio.grpc.FileInfo
-
optional int64 creationTimeMs = 7;
- hasCreationTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 creationTimeMs = 7;
- hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 creation_time_ms = 6;
- hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 creation_time_ms = 6;
- hasCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 creation_time_ms = 6;
- hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 creation_time_ms = 6;
- hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 creation_time_ms = 6;
- hasCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 creation_time_ms = 6;
- hasCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 creation_time_ms = 6;
- hasCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 creation_time_ms = 6;
- hasCreationTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 creation_time_ms = 6;
- hasCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 creation_time_ms = 2;
- hasCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 creation_time_ms = 2;
- hasCreationTimeMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 creation_time_ms = 2;
- hasData() - Method in class alluxio.grpc.Chunk.Builder
-
optional bytes data = 1;
- hasData() - Method in class alluxio.grpc.Chunk
-
optional bytes data = 1;
- hasData() - Method in interface alluxio.grpc.ChunkOrBuilder
-
optional bytes data = 1;
- hasData() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- hasData() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
Deprecated.
- hasData() - Method in interface alluxio.grpc.DownloadSnapshotPResponseOrBuilder
-
Deprecated.
- hasData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- hasData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- hasData() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- hasData() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- hasData() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
Deprecated.
- hasData() - Method in interface alluxio.grpc.UploadSnapshotPRequestOrBuilder
-
Deprecated.
- hasDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
optional string database = 1;
- hasDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest
-
optional string database = 1;
- hasDatabase() - Method in interface alluxio.grpc.table.GetAllTablesPRequestOrBuilder
-
optional string database = 1;
- hasDataPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 dataPort = 3;
- hasDataPort() - Method in class alluxio.grpc.WorkerNetAddress
-
optional int32 dataPort = 3;
- hasDataPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional int32 dataPort = 3;
- hasDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- hasDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- hasDateStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- hasDaysSinceEpoch() - Method in class alluxio.grpc.table.Date.Builder
-
required int64 days_since_epoch = 1;
- hasDaysSinceEpoch() - Method in class alluxio.grpc.table.Date
-
required int64 days_since_epoch = 1;
- hasDaysSinceEpoch() - Method in interface alluxio.grpc.table.DateOrBuilder
-
required int64 days_since_epoch = 1;
- hasDb() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
optional .alluxio.grpc.table.Database db = 1;
- hasDb() - Method in class alluxio.grpc.table.GetDatabasePResponse
-
optional .alluxio.grpc.table.Database db = 1;
- hasDb() - Method in interface alluxio.grpc.table.GetDatabasePResponseOrBuilder
-
optional .alluxio.grpc.table.Database db = 1;
- hasDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string db_name = 4;
- hasDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string db_name = 4;
- hasDbName() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string db_name = 4;
- hasDbName() - Method in class alluxio.grpc.table.Database.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.Database
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.DetachDatabasePRequestOrBuilder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.GetDatabasePRequestOrBuilder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.GetTablePRequest
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string db_name = 3;
- hasDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
optional string db_name = 3;
- hasDbName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
optional string db_name = 3;
- hasDbName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.ReadTablePRequest
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.SyncDatabasePRequestOrBuilder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.TableInfo
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string db_name = 1;
- hasDbName() - Method in class alluxio.grpc.table.TransformTablePRequest
-
optional string db_name = 1;
- hasDbName() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
-
optional string db_name = 1;
- hasDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- hasDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- hasDecimalStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- hasDecommissionedWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 decommissionedWorkerNum = 8;
- hasDecommissionedWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int32 decommissionedWorkerNum = 8;
- hasDecommissionedWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int32 decommissionedWorkerNum = 8;
- hasDefaultAcl() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- hasDefaultAcl() - Method in class alluxio.grpc.FileInfo
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- hasDefaultAcl() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- hasDefaultAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- hasDefaultAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- hasDefaultAcl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- hasDefaultAcl() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- hasDefaultAcl() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- hasDefaultAcl() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- hasDefaultAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- hasDefaultAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- hasDefaultAcl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- hasDefinition() - Method in class alluxio.grpc.table.Transformation.Builder
-
optional string definition = 2;
- hasDefinition() - Method in class alluxio.grpc.table.Transformation
-
optional string definition = 2;
- hasDefinition() - Method in interface alluxio.grpc.table.TransformationOrBuilder
-
optional string definition = 2;
- hasDefinition() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string definition = 3;
- hasDefinition() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string definition = 3;
- hasDefinition() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string definition = 3;
- hasDefinition() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string definition = 3;
- hasDefinition() - Method in class alluxio.grpc.table.TransformTablePRequest
-
optional string definition = 3;
- hasDefinition() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
-
optional string definition = 3;
- hasDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- hasDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- hasDeleteBlock() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- hasDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- hasDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- hasDeleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- hasDeleteMountPoint() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool deleteMountPoint = 6;
- hasDeleteMountPoint() - Method in class alluxio.grpc.DeletePOptions
-
optional bool deleteMountPoint = 6;
- hasDeleteMountPoint() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional bool deleteMountPoint = 6;
- hasDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- hasDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- hasDeleteMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- hasDescription() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string description = 13;
- hasDescription() - Method in class alluxio.grpc.JobInfo
-
optional string description = 13;
- hasDescription() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string description = 13;
- hasDescription() - Method in class alluxio.grpc.table.Database.Builder
-
optional string description = 2;
- hasDescription() - Method in class alluxio.grpc.table.Database
-
optional string description = 2;
- hasDescription() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string description = 2;
- hasDirectChildrenLoaded() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool directChildrenLoaded = 13;
- hasDirectChildrenLoaded() - Method in class alluxio.grpc.SetAttributePOptions
-
optional bool directChildrenLoaded = 13;
- hasDirectChildrenLoaded() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional bool directChildrenLoaded = 13;
- hasDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool direct_children_loaded = 12;
- hasDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional bool direct_children_loaded = 12;
- hasDirectChildrenLoaded() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional bool direct_children_loaded = 12;
- hasDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional bool direct_children_loaded = 3;
- hasDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
optional bool direct_children_loaded = 3;
- hasDirectChildrenLoaded() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
-
optional bool direct_children_loaded = 3;
- hasDisableAreDescendantsLoadedCheck() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
Setting this to true will disable checking during metadata sync to see if the children
of a directory has been loaded.
- hasDisableAreDescendantsLoadedCheck() - Method in class alluxio.grpc.ListStatusPOptions
-
Setting this to true will disable checking during metadata sync to see if the children
of a directory has been loaded.
- hasDisableAreDescendantsLoadedCheck() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
Setting this to true will disable checking during metadata sync to see if the children
of a directory has been loaded.
- hasDomain() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
optional .alluxio.grpc.journal.JournalDomain domain = 1;
- hasDomain() - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
optional .alluxio.grpc.journal.JournalDomain domain = 1;
- hasDomain() - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
-
optional .alluxio.grpc.journal.JournalDomain domain = 1;
- hasDomainSocketPath() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string domainSocketPath = 5;
- hasDomainSocketPath() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string domainSocketPath = 5;
- hasDomainSocketPath() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string domainSocketPath = 5;
- hasDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- hasDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- hasDoubleStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- hasDoubleType() - Method in class alluxio.grpc.table.Value.Builder
-
double double_type = 2;
- hasDoubleType() - Method in class alluxio.grpc.table.Value
-
double double_type = 2;
- hasDoubleType() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
double double_type = 2;
- hasDoubleValue() - Method in class alluxio.grpc.MetricValue.Builder
-
optional double doubleValue = 1;
- hasDoubleValue() - Method in class alluxio.grpc.MetricValue
-
optional double doubleValue = 1;
- hasDoubleValue() - Method in interface alluxio.grpc.MetricValueOrBuilder
-
optional double doubleValue = 1;
- hasDst() - Method in class alluxio.grpc.Route.Builder
-
required string dst = 2;
- hasDst() - Method in class alluxio.grpc.Route
-
required string dst = 2;
- hasDst() - Method in interface alluxio.grpc.RouteOrBuilder
-
required string dst = 2;
- hasDst() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string dst = 2;
- hasDst() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required string dst = 2;
- hasDst() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required string dst = 2;
- hasDst() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string dst = 2;
- hasDst() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required string dst = 2;
- hasDst() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required string dst = 2;
- hasDstPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string dstPath = 3;
- hasDstPath() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string dstPath = 3;
- hasDstPath() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string dstPath = 3;
- hasDstPath() - Method in class alluxio.grpc.RenamePRequest.Builder
-
the destination path
- hasDstPath() - Method in class alluxio.grpc.RenamePRequest
-
the destination path
- hasDstPath() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
-
the destination path
- hasDstPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
Deprecated, use new_parent_id/new_name instead
- hasDstPath() - Method in class alluxio.proto.journal.File.RenameEntry
-
Deprecated, use new_parent_id/new_name instead
- hasDstPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
Deprecated, use new_parent_id/new_name instead
- hasDuration() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 duration = 6;
- hasDuration() - Method in class alluxio.grpc.CmdSummary
-
optional int64 duration = 6;
- hasDuration() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional int64 duration = 6;
- hasEndTime() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional int64 end_time = 9;
- hasEndTime() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional int64 end_time = 9;
- hasEndTime() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional int64 end_time = 9;
- hasEndTime() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional int64 end_time = 8;
- hasEndTime() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional int64 end_time = 8;
- hasEndTime() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional int64 end_time = 8;
- hasEndTime() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional int64 end_time = 9;
- hasEndTime() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional int64 end_time = 9;
- hasEndTime() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional int64 end_time = 9;
- hasEntryCount() - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional int64 entryCount = 5;
- hasEntryCount() - Method in class alluxio.grpc.BackupPStatus
-
optional int64 entryCount = 5;
- hasEntryCount() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
-
optional int64 entryCount = 5;
- hasEof() - Method in class alluxio.grpc.SnapshotData.Builder
-
Deprecated.
- hasEof() - Method in class alluxio.grpc.SnapshotData
-
Deprecated.
- hasEof() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
Deprecated.
- hasEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional bool eof = 5;
- hasEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
optional bool eof = 5;
- hasEof() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
optional bool eof = 5;
- hasEquatable() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- hasEquatable() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- hasEquatable() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- hasErrorMessage() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorMessage = 7;
- hasErrorMessage() - Method in class alluxio.grpc.ActionInfo
-
optional string errorMessage = 7;
- hasErrorMessage() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string errorMessage = 7;
- hasErrorMessage() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional string errorMessage = 7;
- hasErrorMessage() - Method in class alluxio.grpc.CmdSummary
-
optional string errorMessage = 7;
- hasErrorMessage() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional string errorMessage = 7;
- hasErrorMessage() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorMessage = 2;
- hasErrorMessage() - Method in class alluxio.grpc.JobInfo
-
optional string errorMessage = 2;
- hasErrorMessage() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string errorMessage = 2;
- hasErrorMsg() - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorMsg = 5;
- hasErrorMsg() - Method in class alluxio.grpc.JobProgress
-
optional string errorMsg = 5;
- hasErrorMsg() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional string errorMsg = 5;
- hasErrorType() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorType = 6;
- hasErrorType() - Method in class alluxio.grpc.ActionInfo
-
optional string errorType = 6;
- hasErrorType() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string errorType = 6;
- hasErrorType() - Method in class alluxio.grpc.ErrorInfo.Builder
-
optional .alluxio.grpc.ErrorType errorType = 1;
- hasErrorType() - Method in class alluxio.grpc.ErrorInfo
-
optional .alluxio.grpc.ErrorType errorType = 1;
- hasErrorType() - Method in interface alluxio.grpc.ErrorInfoOrBuilder
-
optional .alluxio.grpc.ErrorType errorType = 1;
- hasErrorType() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorType = 15;
- hasErrorType() - Method in class alluxio.grpc.JobInfo
-
optional string errorType = 15;
- hasErrorType() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string errorType = 15;
- hasErrorType() - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorType = 6;
- hasErrorType() - Method in class alluxio.grpc.JobProgress
-
optional string errorType = 6;
- hasErrorType() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional string errorType = 6;
- hasExcludeMountInfo() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
Mount info will be excluded from the list status response if this field is set to true.
- hasExcludeMountInfo() - Method in class alluxio.grpc.ListStatusPOptions
-
Mount info will be excluded from the list status response if this field is set to true.
- hasExcludeMountInfo() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
Mount info will be excluded from the list status response if this field is set to true.
- hasExists() - Method in class alluxio.grpc.ExistsPResponse.Builder
-
optional bool exists = 1;
- hasExists() - Method in class alluxio.grpc.ExistsPResponse
-
optional bool exists = 1;
- hasExists() - Method in interface alluxio.grpc.ExistsPResponseOrBuilder
-
optional bool exists = 1;
- hasExists() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional bool exists = 3;
- hasExists() - Method in class alluxio.grpc.SnapshotMetadata
-
optional bool exists = 3;
- hasExists() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
-
optional bool exists = 3;
- hasExpiryMs() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional int64 expiryMs = 3;
- hasExpiryMs() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
optional int64 expiryMs = 3;
- hasExpiryMs() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
-
optional int64 expiryMs = 3;
- hasExtended() - Method in class alluxio.security.authorization.AccessControlList
-
- hasExtended() - Method in class alluxio.security.authorization.ExtendedACLEntries
-
- hasFailure() - Method in class alluxio.master.job.CopyJob
-
- hasFailure() - Method in class alluxio.master.job.DoraLoadJob
-
- hasFailure() - Method in class alluxio.master.job.LoadJob
-
- hasFailure() - Method in class alluxio.master.job.MoveJob
-
- hasFailure() - Method in interface alluxio.scheduler.job.Job
-
- hasFile(String) - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
- hasFile() - Method in class alluxio.grpc.FileFailure.Builder
-
required .alluxio.grpc.block.File file = 1;
- hasFile() - Method in class alluxio.grpc.FileFailure
-
required .alluxio.grpc.block.File file = 1;
- hasFile() - Method in interface alluxio.grpc.FileFailureOrBuilder
-
required .alluxio.grpc.block.File file = 1;
- hasFileCount() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 fileCount = 2;
- hasFileCount() - Method in class alluxio.grpc.JobProgress
-
optional int64 fileCount = 2;
- hasFileCount() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional int64 fileCount = 2;
- hasFileCount() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
The total number of files in the listing directory,
(i.e.
- hasFileCount() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
The total number of files in the listing directory,
(i.e.
- hasFileCount() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
-
The total number of files in the listing directory,
(i.e.
- hasFileDatePattern() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string file_date_pattern = 6;
- hasFileDatePattern() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string file_date_pattern = 6;
- hasFileDatePattern() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string file_date_pattern = 6;
- hasFileId() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 fileId = 1;
- hasFileId() - Method in class alluxio.grpc.FileInfo
-
optional int64 fileId = 1;
- hasFileId() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 fileId = 1;
- hasFileId() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
the id of the file
- hasFileId() - Method in class alluxio.grpc.GetFileInfoPRequest
-
the id of the file
- hasFileId() - Method in interface alluxio.grpc.GetFileInfoPRequestOrBuilder
-
the id of the file
- hasFileId() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
optional int64 fileId = 1;
- hasFileId() - Method in class alluxio.grpc.GetFilePathPRequest
-
optional int64 fileId = 1;
- hasFileId() - Method in interface alluxio.grpc.GetFilePathPRequestOrBuilder
-
optional int64 fileId = 1;
- hasFileId() - Method in class alluxio.grpc.PersistFile.Builder
-
optional int64 fileId = 1;
- hasFileId() - Method in class alluxio.grpc.PersistFile
-
optional int64 fileId = 1;
- hasFileId() - Method in interface alluxio.grpc.PersistFileOrBuilder
-
optional int64 fileId = 1;
- hasFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
optional int64 file_id = 1;
- hasFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
-
optional int64 file_id = 1;
- hasFileId() - Method in interface alluxio.proto.journal.File.AsyncPersistRequestEntryOrBuilder
-
optional int64 file_id = 1;
- hasFileInfo() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in class alluxio.grpc.CreateFilePResponse
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in class alluxio.grpc.GetFileInfoPResponse
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in interface alluxio.grpc.GetFileInfoPResponseOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in class alluxio.grpc.GetStatusPResponse
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in interface alluxio.grpc.GetStatusPResponseOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFileInfo() - Method in interface alluxio.proto.meta.DoraMeta.FileStatusOrBuilder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- hasFilePath() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string filePath = 4;
- hasFilePath() - Method in class alluxio.grpc.ActionInfo
-
optional string filePath = 4;
- hasFilePath() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional string filePath = 4;
- hasFilePath() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string filePath = 3;
- hasFilePath() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional string filePath = 3;
- hasFilePath() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional string filePath = 3;
- hasFilePath() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePath = 3;
- hasFilePath() - Method in class alluxio.grpc.JobStatusBlock
-
optional string filePath = 3;
- hasFilePath() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
-
optional string filePath = 3;
- hasFilePathFailed() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePathFailed = 4;
- hasFilePathFailed() - Method in class alluxio.grpc.JobStatusBlock
-
optional string filePathFailed = 4;
- hasFilePathFailed() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
-
optional string filePathFailed = 4;
- hasFileSize() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 fileSize = 3;
- hasFileSize() - Method in class alluxio.grpc.JobProgress
-
optional int64 fileSize = 3;
- hasFileSize() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional int64 fileSize = 3;
- hasFilesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
optional int32 files_skipped = 3;
- hasFilesSkipped() - Method in class alluxio.grpc.LoadFileResponse
-
optional int32 files_skipped = 3;
- hasFilesSkipped() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
optional int32 files_skipped = 3;
- hasFilter() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string filter = 5;
- hasFilter() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string filter = 5;
- hasFilter() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string filter = 5;
- hasFilter() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- hasFilter() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- hasFilter() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- hasFilter() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- hasFilter() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- hasFilter() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- hasFlush() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional bool flush = 5;
- hasFlush() - Method in class alluxio.grpc.WriteRequestCommand
-
optional bool flush = 5;
- hasFlush() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional bool flush = 5;
- hasFolder() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool folder = 9;
- hasFolder() - Method in class alluxio.grpc.FileInfo
-
optional bool folder = 9;
- hasFolder() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool folder = 9;
- hasForced() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional bool forced = 2;
- hasForced() - Method in class alluxio.grpc.FreePOptions
-
optional bool forced = 2;
- hasForced() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
-
optional bool forced = 2;
- hasFormat() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
- hasFormat() - Method in class alluxio.grpc.GetJobProgressPResponse
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
- hasFormat() - Method in interface alluxio.grpc.GetJobProgressPResponseOrBuilder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
- hasFormat() - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
- hasFormat() - Method in class alluxio.grpc.JobProgressPOptions
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
- hasFormat() - Method in interface alluxio.grpc.JobProgressPOptionsOrBuilder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
- hasFreeBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 freeBytes = 3;
- hasFreeBytes() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int64 freeBytes = 3;
- hasFreeBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int64 freeBytes = 3;
- hasGroup() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string group = 17;
- hasGroup() - Method in class alluxio.grpc.FileInfo
-
optional string group = 17;
- hasGroup() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string group = 17;
- hasGroup() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string group = 4;
- hasGroup() - Method in class alluxio.grpc.SetAttributePOptions
-
optional string group = 4;
- hasGroup() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional string group = 4;
- hasGroup() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string group = 5;
- hasGroup() - Method in class alluxio.grpc.UfsStatus
-
optional string group = 5;
- hasGroup() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string group = 5;
- hasGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string group = 3;
- hasGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional string group = 3;
- hasGroup() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional string group = 3;
- hasGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string group = 9;
- hasGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string group = 9;
- hasGroup() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string group = 9;
- hasGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string group = 15;
- hasGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string group = 15;
- hasGroup() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string group = 15;
- hasGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string group = 7;
- hasGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string group = 7;
- hasGroup() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string group = 7;
- hasGroup() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string group = 10;
- hasGroup() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string group = 10;
- hasGroup() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string group = 10;
- hasGroupBits() - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits groupBits = 2;
- hasGroupBits() - Method in class alluxio.grpc.PMode
-
required .alluxio.grpc.Bits groupBits = 2;
- hasGroupBits() - Method in interface alluxio.grpc.PModeOrBuilder
-
required .alluxio.grpc.Bits groupBits = 2;
- hash() - Method in class alluxio.AlluxioURI
-
Computes the hash of this URI, with SHA-256, or MD5, or simple hashCode().
- hash(String) - Static method in class alluxio.AlluxioURI
-
Computes the hash of this URI, with SHA-256, or MD5, or simple hashCode().
- hash() - Method in interface alluxio.conf.AlluxioConfiguration
-
- hash() - Method in class alluxio.conf.AlluxioProperties
-
- hash() - Static method in class alluxio.conf.Configuration
-
- Hash - Class in alluxio.conf
-
A hex encoded MD5 hash of the cluster or path configurations.
- Hash(Supplier<Stream<byte[]>>) - Constructor for class alluxio.conf.Hash
-
- hash() - Method in class alluxio.conf.InstancedConfiguration
-
- hash() - Method in class alluxio.master.meta.PathProperties
-
- hash(String) - Static method in class alluxio.s3.signature.StringToSignProducer
-
Compute a hash for provided string.
- hash(int, String) - Static method in class alluxio.util.URIUtils
-
Hashes a string for a URI hash.
- HashAllocator - Class in alluxio.client.file.cache.allocator
-
An implementation of Allocator base on the hash of the file id for local cache.
- HashAllocator(List<PageStoreDir>) - Constructor for class alluxio.client.file.cache.allocator.HashAllocator
-
- HashAllocator(List<PageStoreDir>, Function<String, Integer>) - Constructor for class alluxio.client.file.cache.allocator.HashAllocator
-
- hasHasDirectChildrenLoaded() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool has_direct_children_loaded = 13;
- hasHasDirectChildrenLoaded() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional bool has_direct_children_loaded = 13;
- hasHasDirectChildrenLoaded() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional bool has_direct_children_loaded = 13;
- hashAsLong(String) - Static method in class alluxio.util.HashUtils
-
Hash the give obj as long with given HASH_FUNCTION.
- hashAsStringMD5(String) - Static method in class alluxio.util.HashUtils
-
MD5 Hash the given obj as string.
- HashBasedWorkerAssignPolicy - Class in alluxio.master.job
-
Policy which employs Hash-Based algorithm to select worker from given workers set.
- HashBasedWorkerAssignPolicy() - Constructor for class alluxio.master.job.HashBasedWorkerAssignPolicy
-
- hashCode() - Method in class alluxio.AlluxioURI
-
- hashCode() - Method in class alluxio.cli.docgen.MetricsDocGenerator.FileWriterKey
-
- hashCode() - Method in class alluxio.cli.fs.command.FileLocation
-
- hashCode() - Method in class alluxio.cli.LogLevel.TargetInfo
-
- hashCode() - Method in class alluxio.client.block.options.GetWorkerReportOptions
-
- hashCode() - Method in class alluxio.client.file.cache.CacheUsage.DirPartition
-
- hashCode() - Method in class alluxio.client.file.cache.CacheUsage.FilePartition
-
- hashCode() - Method in class alluxio.client.file.cache.CacheUsage.ScopePartition
-
- hashCode() - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
-
- hashCode() - Method in class alluxio.client.file.cache.PageId
-
- hashCode() - Method in class alluxio.client.file.cache.PageInfo
-
- hashCode() - Method in class alluxio.client.file.CacheContext
-
- hashCode() - Method in class alluxio.client.file.FileSystemCache.Key
-
- hashCode() - Method in class alluxio.client.file.FileSystemContext.ClientPoolKey
-
- hashCode() - Method in class alluxio.client.file.options.InStreamOptions
-
- hashCode() - Method in class alluxio.client.file.options.OutStreamOptions
-
- hashCode() - Method in class alluxio.client.file.URIStatus
-
- hashCode() - Method in class alluxio.client.hive.HiveCacheContext
-
- hashCode() - Method in class alluxio.client.quota.CacheQuota
-
- hashCode() - Method in class alluxio.client.quota.CacheScope
-
- hashCode() - Method in class alluxio.collections.DelegatingSet
-
- hashCode() - Method in class alluxio.collections.Pair
-
- hashCode() - Method in class alluxio.collections.TwoKeyConcurrentMap
-
The hashCode implementation for this map simply uses the superclass's.
- hashCode() - Method in class alluxio.conf.PropertyKey
-
- hashCode() - Method in class alluxio.conf.Source
-
- hashCode() - Method in class alluxio.fuse.options.FuseCliOptions
-
- hashCode() - Method in class alluxio.fuse.options.MountCliOptions
-
- hashCode() - Method in class alluxio.fuse.options.MountOptions
-
- hashCode() - Method in class alluxio.grpc.ActionInfo
-
- hashCode() - Method in class alluxio.grpc.AddPolicyPOptions
-
- hashCode() - Method in class alluxio.grpc.AddPolicyPRequest
-
- hashCode() - Method in class alluxio.grpc.AddPolicyPResponse
-
- hashCode() - Method in class alluxio.grpc.AddQuorumServerRequest
-
- hashCode() - Method in class alluxio.grpc.AsyncCacheRequest
-
- hashCode() - Method in class alluxio.grpc.AsyncCacheResponse
-
- hashCode() - Method in class alluxio.grpc.BackupPOptions
-
- hashCode() - Method in class alluxio.grpc.BackupPRequest
-
- hashCode() - Method in class alluxio.grpc.BackupPStatus
-
- hashCode() - Method in class alluxio.grpc.BackupStatusPRequest
-
- hashCode() - Method in class alluxio.grpc.Block
-
- hashCode() - Method in class alluxio.grpc.BlockHeartbeatPOptions
-
- hashCode() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
- hashCode() - Method in class alluxio.grpc.BlockHeartbeatPResponse
-
- hashCode() - Method in class alluxio.grpc.BlockIdList
-
- hashCode() - Method in class alluxio.grpc.BlockInfo
-
- hashCode() - Method in class alluxio.grpc.BlockLocation
-
- hashCode() - Method in class alluxio.grpc.BlockMasterInfo
-
- hashCode() - Method in class alluxio.grpc.BlockStatus
-
- hashCode() - Method in class alluxio.grpc.BlockStoreLocationProto
-
- hashCode() - Method in class alluxio.grpc.BuildVersion
-
- hashCode() - Method in class alluxio.grpc.CacheRequest
-
- hashCode() - Method in class alluxio.grpc.CacheResponse
-
- hashCode() - Method in class alluxio.grpc.CancelPOptions
-
- hashCode() - Method in class alluxio.grpc.CancelPRequest
-
- hashCode() - Method in class alluxio.grpc.CancelPResponse
-
- hashCode() - Method in class alluxio.grpc.CancelTaskCommand
-
- hashCode() - Method in class alluxio.grpc.CheckAccessPOptions
-
- hashCode() - Method in class alluxio.grpc.CheckAccessPRequest
-
- hashCode() - Method in class alluxio.grpc.CheckAccessPResponse
-
- hashCode() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
- hashCode() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
- hashCode() - Method in class alluxio.grpc.CheckConsistencyPResponse
-
- hashCode() - Method in class alluxio.grpc.CheckpointPOptions
-
- hashCode() - Method in class alluxio.grpc.CheckpointPResponse
-
- hashCode() - Method in class alluxio.grpc.CheckRequest
-
- hashCode() - Method in class alluxio.grpc.CheckResponse
-
- hashCode() - Method in class alluxio.grpc.Chunk
-
- hashCode() - Method in class alluxio.grpc.ClearMetricsPRequest
-
- hashCode() - Method in class alluxio.grpc.ClearMetricsPResponse
-
- hashCode() - Method in class alluxio.grpc.ClearMetricsRequest
-
- hashCode() - Method in class alluxio.grpc.ClearMetricsResponse
-
- hashCode() - Method in class alluxio.grpc.ClientMetrics
-
- hashCode() - Method in class alluxio.grpc.CmdProgress
-
- hashCode() - Method in class alluxio.grpc.CmdStatusBlock
-
- hashCode() - Method in class alluxio.grpc.CmdSummary
-
- hashCode() - Method in class alluxio.grpc.Command
-
- hashCode() - Method in class alluxio.grpc.CommitBlockPOptions
-
- hashCode() - Method in class alluxio.grpc.CommitBlockPRequest
-
- hashCode() - Method in class alluxio.grpc.CommitBlockPResponse
-
- hashCode() - Method in class alluxio.grpc.CompleteFilePOptions
-
- hashCode() - Method in class alluxio.grpc.CompleteFilePRequest
-
- hashCode() - Method in class alluxio.grpc.CompleteFilePResponse
-
- hashCode() - Method in class alluxio.grpc.ConfigCheckReport
-
- hashCode() - Method in class alluxio.grpc.ConfigProperties
-
- hashCode() - Method in class alluxio.grpc.ConfigProperty
-
- hashCode() - Method in class alluxio.grpc.CopyJobPOptions
-
- hashCode() - Method in class alluxio.grpc.CopyRequest
-
- hashCode() - Method in class alluxio.grpc.CopyResponse
-
- hashCode() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
- hashCode() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
- hashCode() - Method in class alluxio.grpc.CreateDirectoryPResponse
-
- hashCode() - Method in class alluxio.grpc.CreateFilePOptions
-
- hashCode() - Method in class alluxio.grpc.CreateFilePRequest
-
- hashCode() - Method in class alluxio.grpc.CreateFilePResponse
-
- hashCode() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
- hashCode() - Method in class alluxio.grpc.DecommissionWorkerPResponse
-
- hashCode() - Method in class alluxio.grpc.DeletePOptions
-
- hashCode() - Method in class alluxio.grpc.DeletePRequest
-
- hashCode() - Method in class alluxio.grpc.DeletePResponse
-
- hashCode() - Method in class alluxio.grpc.DownloadSnapshotPRequest
-
Deprecated.
- hashCode() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
Deprecated.
- hashCode() - Method in class alluxio.grpc.ErrorInfo
-
- hashCode() - Method in class alluxio.grpc.ExistsPOptions
-
- hashCode() - Method in class alluxio.grpc.ExistsPRequest
-
- hashCode() - Method in class alluxio.grpc.ExistsPResponse
-
- hashCode() - Method in class alluxio.grpc.File
-
- hashCode() - Method in class alluxio.grpc.FileBlockInfo
-
- hashCode() - Method in class alluxio.grpc.FileFailure
-
- hashCode() - Method in class alluxio.grpc.FileInfo
-
- hashCode() - Method in class alluxio.grpc.FileSystemCommand
-
- hashCode() - Method in class alluxio.grpc.FileSystemCommandOptions
-
- hashCode() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
-
- hashCode() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
- hashCode() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
-
- hashCode() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
- hashCode() - Method in class alluxio.grpc.FreePOptions
-
- hashCode() - Method in class alluxio.grpc.FreePRequest
-
- hashCode() - Method in class alluxio.grpc.FreePResponse
-
- hashCode() - Method in class alluxio.grpc.FreeWorkerRequest
-
- hashCode() - Method in class alluxio.grpc.FreeWorkerResponse
-
- hashCode() - Method in class alluxio.grpc.FsOpPId
-
- hashCode() - Method in class alluxio.grpc.GetActionInfoOptions
-
- hashCode() - Method in class alluxio.grpc.GetActionInfoRequest
-
- hashCode() - Method in class alluxio.grpc.GetActionInfoResponse
-
- hashCode() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
-
- hashCode() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
-
- hashCode() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
-
- hashCode() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
-
- hashCode() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
-
- hashCode() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
-
- hashCode() - Method in class alluxio.grpc.GetBlockInfoPOptions
-
- hashCode() - Method in class alluxio.grpc.GetBlockInfoPRequest
-
- hashCode() - Method in class alluxio.grpc.GetBlockInfoPResponse
-
- hashCode() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
-
- hashCode() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
-
- hashCode() - Method in class alluxio.grpc.GetCapacityBytesPOptions
-
- hashCode() - Method in class alluxio.grpc.GetCapacityBytesPResponse
-
- hashCode() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
-
- hashCode() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
- hashCode() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
-
- hashCode() - Method in class alluxio.grpc.GetCmdStatusOptions
-
- hashCode() - Method in class alluxio.grpc.GetCmdStatusRequest
-
- hashCode() - Method in class alluxio.grpc.GetCmdStatusResponse
-
- hashCode() - Method in class alluxio.grpc.GetConfigHashPOptions
-
- hashCode() - Method in class alluxio.grpc.GetConfigHashPResponse
-
- hashCode() - Method in class alluxio.grpc.GetConfigReportPOptions
-
- hashCode() - Method in class alluxio.grpc.GetConfigReportPResponse
-
- hashCode() - Method in class alluxio.grpc.GetConfigurationPOptions
-
- hashCode() - Method in class alluxio.grpc.GetConfigurationPResponse
-
- hashCode() - Method in class alluxio.grpc.GetFileInfoPOptions
-
- hashCode() - Method in class alluxio.grpc.GetFileInfoPRequest
-
- hashCode() - Method in class alluxio.grpc.GetFileInfoPResponse
-
- hashCode() - Method in class alluxio.grpc.GetFilePathPRequest
-
- hashCode() - Method in class alluxio.grpc.GetFilePathPResponse
-
- hashCode() - Method in class alluxio.grpc.GetJobMasterIdPOptions
-
- hashCode() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
- hashCode() - Method in class alluxio.grpc.GetJobMasterIdPResponse
-
- hashCode() - Method in class alluxio.grpc.GetJobProgressPRequest
-
- hashCode() - Method in class alluxio.grpc.GetJobProgressPResponse
-
- hashCode() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
-
- hashCode() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
-
- hashCode() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
-
- hashCode() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
-
- hashCode() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
- hashCode() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
- hashCode() - Method in class alluxio.grpc.GetJobStatusPOptions
-
- hashCode() - Method in class alluxio.grpc.GetJobStatusPRequest
-
- hashCode() - Method in class alluxio.grpc.GetJobStatusPResponse
-
- hashCode() - Method in class alluxio.grpc.GetMasterIdPOptions
-
- hashCode() - Method in class alluxio.grpc.GetMasterIdPRequest
-
- hashCode() - Method in class alluxio.grpc.GetMasterIdPResponse
-
- hashCode() - Method in class alluxio.grpc.GetMasterInfoPOptions
-
- hashCode() - Method in class alluxio.grpc.GetMasterInfoPResponse
-
- hashCode() - Method in class alluxio.grpc.GetMetricsPOptions
-
- hashCode() - Method in class alluxio.grpc.GetMetricsPResponse
-
- hashCode() - Method in class alluxio.grpc.GetMountIdPRequest
-
- hashCode() - Method in class alluxio.grpc.GetMountIdPResponse
-
- hashCode() - Method in class alluxio.grpc.GetMountTablePRequest
-
- hashCode() - Method in class alluxio.grpc.GetMountTablePResponse
-
- hashCode() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
- hashCode() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
- hashCode() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
-
- hashCode() - Method in class alluxio.grpc.GetNodeStatePRequest
-
- hashCode() - Method in class alluxio.grpc.GetNodeStatePResponse
-
- hashCode() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
-
- hashCode() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
-
- hashCode() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
-
- hashCode() - Method in class alluxio.grpc.GetPolicyStatusPOptions
-
- hashCode() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
- hashCode() - Method in class alluxio.grpc.GetPolicyStatusPResponse
-
- hashCode() - Method in class alluxio.grpc.GetQuorumInfoPOptions
-
- hashCode() - Method in class alluxio.grpc.GetQuorumInfoPRequest
-
- hashCode() - Method in class alluxio.grpc.GetQuorumInfoPResponse
-
- hashCode() - Method in class alluxio.grpc.GetRegisterLeasePOptions
-
- hashCode() - Method in class alluxio.grpc.GetRegisterLeasePRequest
-
- hashCode() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
- hashCode() - Method in class alluxio.grpc.GetServiceVersionPRequest
-
- hashCode() - Method in class alluxio.grpc.GetServiceVersionPResponse
-
- hashCode() - Method in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- hashCode() - Method in class alluxio.grpc.GetSnapshotInfoResponse
-
Deprecated.
- hashCode() - Method in class alluxio.grpc.GetSnapshotRequest
-
Deprecated.
- hashCode() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
-
- hashCode() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
-
- hashCode() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
-
- hashCode() - Method in class alluxio.grpc.GetStatusPOptions
-
- hashCode() - Method in class alluxio.grpc.GetStatusPRequest
-
- hashCode() - Method in class alluxio.grpc.GetStatusPResponse
-
- hashCode() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
-
- hashCode() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
-
- hashCode() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
-
- hashCode() - Method in class alluxio.grpc.GetUfsInfoPOptions
-
- hashCode() - Method in class alluxio.grpc.GetUfsInfoPRequest
-
- hashCode() - Method in class alluxio.grpc.GetUfsInfoPResponse
-
- hashCode() - Method in class alluxio.grpc.GetUsedBytesPOptions
-
- hashCode() - Method in class alluxio.grpc.GetUsedBytesPResponse
-
- hashCode() - Method in class alluxio.grpc.GetWorkerIdPOptions
-
- hashCode() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
- hashCode() - Method in class alluxio.grpc.GetWorkerIdPResponse
-
- hashCode() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
-
- hashCode() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
-
- hashCode() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
-
- hashCode() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
-
- hashCode() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
- hashCode() - Method in class alluxio.grpc.GrpcChannel
-
- hashCode() - Method in class alluxio.grpc.GrpcChannelKey
-
- hashCode() - Method in class alluxio.grpc.GrpcServerAddress
-
- hashCode() - Method in class alluxio.grpc.InconsistentProperties
-
- hashCode() - Method in class alluxio.grpc.InconsistentProperty
-
- hashCode() - Method in class alluxio.grpc.InconsistentPropertyValues
-
- hashCode() - Method in class alluxio.grpc.JobCommand
-
- hashCode() - Method in class alluxio.grpc.JobDescription
-
- hashCode() - Method in class alluxio.grpc.JobHeartbeatPOptions
-
- hashCode() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
- hashCode() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
- hashCode() - Method in class alluxio.grpc.JobInfo
-
- hashCode() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
-
- hashCode() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
- hashCode() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
-
- hashCode() - Method in class alluxio.grpc.JobMasterStatus
-
- hashCode() - Method in class alluxio.grpc.JobProgress
-
- hashCode() - Method in class alluxio.grpc.JobProgressPOptions
-
- hashCode() - Method in class alluxio.grpc.JobServiceSummary
-
- hashCode() - Method in class alluxio.grpc.JobStatusBlock
-
- hashCode() - Method in class alluxio.grpc.JobUnused
-
- hashCode() - Method in class alluxio.grpc.JobWorkerHealth
-
- hashCode() - Method in class alluxio.grpc.JournalQueryRequest
-
- hashCode() - Method in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- hashCode() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
-
- hashCode() - Method in class alluxio.grpc.ListAllPOptions
-
- hashCode() - Method in class alluxio.grpc.ListAllPRequest
-
- hashCode() - Method in class alluxio.grpc.ListAllPResponse
-
- hashCode() - Method in class alluxio.grpc.ListPolicyPOptions
-
- hashCode() - Method in class alluxio.grpc.ListPolicyPRequest
-
- hashCode() - Method in class alluxio.grpc.ListPolicyPResponse
-
- hashCode() - Method in class alluxio.grpc.ListProxyStatusPOptions
-
- hashCode() - Method in class alluxio.grpc.ListProxyStatusPRequest
-
- hashCode() - Method in class alluxio.grpc.ListProxyStatusPResponse
-
- hashCode() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
- hashCode() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
- hashCode() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
- hashCode() - Method in class alluxio.grpc.ListStatusPOptions
-
- hashCode() - Method in class alluxio.grpc.ListStatusPRequest
-
- hashCode() - Method in class alluxio.grpc.ListStatusPResponse
-
- hashCode() - Method in class alluxio.grpc.LoadFileFailure
-
- hashCode() - Method in class alluxio.grpc.LoadFileRequest
-
- hashCode() - Method in class alluxio.grpc.LoadFileResponse
-
- hashCode() - Method in class alluxio.grpc.LoadJobPOptions
-
- hashCode() - Method in class alluxio.grpc.LoadMetadataPOptions
-
- hashCode() - Method in class alluxio.grpc.LoadRequest
-
- hashCode() - Method in class alluxio.grpc.LoadResponse
-
- hashCode() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
- hashCode() - Method in class alluxio.grpc.MasterHeartbeatPOptions
-
- hashCode() - Method in class alluxio.grpc.MasterHeartbeatPRequest
-
- hashCode() - Method in class alluxio.grpc.MasterHeartbeatPResponse
-
- hashCode() - Method in class alluxio.grpc.MasterInfo
-
- hashCode() - Method in class alluxio.grpc.MasterVersion
-
- hashCode() - Method in class alluxio.grpc.MessagingRequestHeader
-
- hashCode() - Method in class alluxio.grpc.MessagingResponseHeader
-
- hashCode() - Method in class alluxio.grpc.Metric
-
- hashCode() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
-
- hashCode() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
-
- hashCode() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
-
- hashCode() - Method in class alluxio.grpc.MetricValue
-
- hashCode() - Method in class alluxio.grpc.MountPointInfo
-
- hashCode() - Method in class alluxio.grpc.MountPOptions
-
- hashCode() - Method in class alluxio.grpc.MountPRequest
-
- hashCode() - Method in class alluxio.grpc.MountPResponse
-
- hashCode() - Method in class alluxio.grpc.MoveBlockRequest
-
- hashCode() - Method in class alluxio.grpc.MoveBlockResponse
-
- hashCode() - Method in class alluxio.grpc.MoveJobPOptions
-
- hashCode() - Method in class alluxio.grpc.MoveRequest
-
- hashCode() - Method in class alluxio.grpc.MoveResponse
-
- hashCode() - Method in class alluxio.grpc.NeedsSyncRequest
-
- hashCode() - Method in class alluxio.grpc.NeedsSyncResponse
-
- hashCode() - Method in class alluxio.grpc.NetAddress
-
- hashCode() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
-
- hashCode() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
- hashCode() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
-
- hashCode() - Method in class alluxio.grpc.OpenFilePOptions
-
- hashCode() - Method in class alluxio.grpc.PAcl
-
- hashCode() - Method in class alluxio.grpc.PAclEntry
-
- hashCode() - Method in class alluxio.grpc.PersistCommandOptions
-
- hashCode() - Method in class alluxio.grpc.PersistFile
-
- hashCode() - Method in class alluxio.grpc.PMode
-
- hashCode() - Method in class alluxio.grpc.PolicyInfo
-
- hashCode() - Method in class alluxio.grpc.PolicyStatus
-
- hashCode() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
- hashCode() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
-
- hashCode() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
-
- hashCode() - Method in class alluxio.grpc.ProxyStatus
-
- hashCode() - Method in class alluxio.grpc.QuorumServerInfo
-
- hashCode() - Method in class alluxio.grpc.ReadRequest
-
- hashCode() - Method in class alluxio.grpc.ReadResponse
-
- hashCode() - Method in class alluxio.grpc.RegisterCommand
-
- hashCode() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
- hashCode() - Method in class alluxio.grpc.RegisterJobMasterPRequest
-
- hashCode() - Method in class alluxio.grpc.RegisterJobMasterPResponse
-
- hashCode() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
-
- hashCode() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
- hashCode() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
-
- hashCode() - Method in class alluxio.grpc.RegisterMasterPOptions
-
- hashCode() - Method in class alluxio.grpc.RegisterMasterPRequest
-
- hashCode() - Method in class alluxio.grpc.RegisterMasterPResponse
-
- hashCode() - Method in class alluxio.grpc.RegisterWorkerPOptions
-
- hashCode() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
- hashCode() - Method in class alluxio.grpc.RegisterWorkerPResponse
-
- hashCode() - Method in class alluxio.grpc.RemoveBlockRequest
-
- hashCode() - Method in class alluxio.grpc.RemoveBlockResponse
-
- hashCode() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
- hashCode() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
-
- hashCode() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
-
- hashCode() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
- hashCode() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
-
- hashCode() - Method in class alluxio.grpc.RemovePolicyPOptions
-
- hashCode() - Method in class alluxio.grpc.RemovePolicyPRequest
-
- hashCode() - Method in class alluxio.grpc.RemovePolicyPResponse
-
- hashCode() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
-
- hashCode() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
- hashCode() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
-
- hashCode() - Method in class alluxio.grpc.RenamePOptions
-
- hashCode() - Method in class alluxio.grpc.RenamePRequest
-
- hashCode() - Method in class alluxio.grpc.RenamePResponse
-
- hashCode() - Method in class alluxio.grpc.ResetPrioritiesPOptions
-
- hashCode() - Method in class alluxio.grpc.ResetPrioritiesPRequest
-
- hashCode() - Method in class alluxio.grpc.ResetPrioritiesPResponse
-
- hashCode() - Method in class alluxio.grpc.RetryInfo
-
- hashCode() - Method in class alluxio.grpc.ReverseResolvePRequest
-
- hashCode() - Method in class alluxio.grpc.ReverseResolvePResponse
-
- hashCode() - Method in class alluxio.grpc.Route
-
- hashCode() - Method in class alluxio.grpc.RouteFailure
-
- hashCode() - Method in class alluxio.grpc.RunPOptions
-
- hashCode() - Method in class alluxio.grpc.RunPRequest
-
- hashCode() - Method in class alluxio.grpc.RunPResponse
-
- hashCode() - Method in class alluxio.grpc.RunTaskCommand
-
- hashCode() - Method in class alluxio.grpc.S3SyntaxOptions
-
- hashCode() - Method in class alluxio.grpc.SaslMessage
-
- hashCode() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
- hashCode() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
- hashCode() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
-
- hashCode() - Method in class alluxio.grpc.SetAclPOptions
-
- hashCode() - Method in class alluxio.grpc.SetAclPRequest
-
- hashCode() - Method in class alluxio.grpc.SetAclPResponse
-
- hashCode() - Method in class alluxio.grpc.SetAttributePOptions
-
- hashCode() - Method in class alluxio.grpc.SetAttributePRequest
-
- hashCode() - Method in class alluxio.grpc.SetAttributePResponse
-
- hashCode() - Method in class alluxio.grpc.SetPathConfigurationPOptions
-
- hashCode() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
- hashCode() - Method in class alluxio.grpc.SetPathConfigurationPResponse
-
- hashCode() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
-
- hashCode() - Method in class alluxio.grpc.SnapshotData
-
- hashCode() - Method in class alluxio.grpc.SnapshotMetadata
-
- hashCode() - Method in class alluxio.grpc.StatusSummary
-
- hashCode() - Method in class alluxio.grpc.StopJobPRequest
-
- hashCode() - Method in class alluxio.grpc.StopJobPResponse
-
- hashCode() - Method in class alluxio.grpc.StorageList
-
- hashCode() - Method in class alluxio.grpc.SubmitJobPRequest
-
- hashCode() - Method in class alluxio.grpc.SubmitJobPResponse
-
- hashCode() - Method in class alluxio.grpc.SubmitOptions
-
- hashCode() - Method in class alluxio.grpc.SubmitRequest
-
- hashCode() - Method in class alluxio.grpc.SubmitResponse
-
- hashCode() - Method in class alluxio.grpc.table.AllOrNoneSet
-
- hashCode() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
- hashCode() - Method in class alluxio.grpc.table.AttachDatabasePResponse
-
- hashCode() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
- hashCode() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
- hashCode() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
- hashCode() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
- hashCode() - Method in class alluxio.grpc.table.ColumnStatisticsList
-
- hashCode() - Method in class alluxio.grpc.table.Constraint
-
- hashCode() - Method in class alluxio.grpc.table.Database
-
- hashCode() - Method in class alluxio.grpc.table.Date
-
- hashCode() - Method in class alluxio.grpc.table.DateColumnStatsData
-
- hashCode() - Method in class alluxio.grpc.table.Decimal
-
- hashCode() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
- hashCode() - Method in class alluxio.grpc.table.DetachDatabasePRequest
-
- hashCode() - Method in class alluxio.grpc.table.DetachDatabasePResponse
-
- hashCode() - Method in class alluxio.grpc.table.Domain
-
- hashCode() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
- hashCode() - Method in class alluxio.grpc.table.EquatableValueSet
-
- hashCode() - Method in class alluxio.grpc.table.FieldSchema
-
- hashCode() - Method in class alluxio.grpc.table.FileStatistics
-
- hashCode() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
-
- hashCode() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
- hashCode() - Method in class alluxio.grpc.table.GetAllTablesPRequest
-
- hashCode() - Method in class alluxio.grpc.table.GetAllTablesPResponse
-
- hashCode() - Method in class alluxio.grpc.table.GetDatabasePRequest
-
- hashCode() - Method in class alluxio.grpc.table.GetDatabasePResponse
-
- hashCode() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
- hashCode() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
-
- hashCode() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
- hashCode() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
- hashCode() - Method in class alluxio.grpc.table.GetTablePRequest
-
- hashCode() - Method in class alluxio.grpc.table.GetTablePResponse
-
- hashCode() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
-
- hashCode() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
-
- hashCode() - Method in class alluxio.grpc.table.Layout
-
- hashCode() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
- hashCode() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
- hashCode() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
-
- hashCode() - Method in class alluxio.grpc.table.layout.hive.Storage
-
- hashCode() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
- hashCode() - Method in class alluxio.grpc.table.LayoutSpec
-
- hashCode() - Method in class alluxio.grpc.table.LongColumnStatsData
-
- hashCode() - Method in class alluxio.grpc.table.Partition
-
- hashCode() - Method in class alluxio.grpc.table.PartitionSpec
-
- hashCode() - Method in class alluxio.grpc.table.Range
-
- hashCode() - Method in class alluxio.grpc.table.RangeSet
-
- hashCode() - Method in class alluxio.grpc.table.ReadTablePRequest
-
- hashCode() - Method in class alluxio.grpc.table.ReadTablePResponse
-
- hashCode() - Method in class alluxio.grpc.table.Schema
-
- hashCode() - Method in class alluxio.grpc.table.StringColumnStatsData
-
- hashCode() - Method in class alluxio.grpc.table.SyncDatabasePRequest
-
- hashCode() - Method in class alluxio.grpc.table.SyncDatabasePResponse
-
- hashCode() - Method in class alluxio.grpc.table.SyncStatus
-
- hashCode() - Method in class alluxio.grpc.table.TableInfo
-
- hashCode() - Method in class alluxio.grpc.table.Transformation
-
- hashCode() - Method in class alluxio.grpc.table.TransformJobInfo
-
- hashCode() - Method in class alluxio.grpc.table.TransformTablePRequest
-
- hashCode() - Method in class alluxio.grpc.table.TransformTablePResponse
-
- hashCode() - Method in class alluxio.grpc.table.Value
-
- hashCode() - Method in class alluxio.grpc.TierList
-
- hashCode() - Method in class alluxio.grpc.TransferLeaderMessage
-
- hashCode() - Method in class alluxio.grpc.TransferLeadershipPOptions
-
- hashCode() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
- hashCode() - Method in class alluxio.grpc.TransferLeadershipPResponse
-
- hashCode() - Method in class alluxio.grpc.TransportMessage
-
- hashCode() - Method in class alluxio.grpc.TriggerPolicyRequest
-
- hashCode() - Method in class alluxio.grpc.TriggerPolicyResponse
-
- hashCode() - Method in class alluxio.grpc.UfsFileStatus
-
- hashCode() - Method in class alluxio.grpc.UfsInfo
-
- hashCode() - Method in class alluxio.grpc.UfsReadOptions
-
- hashCode() - Method in class alluxio.grpc.UfsStatus
-
- hashCode() - Method in class alluxio.grpc.UnmountPOptions
-
- hashCode() - Method in class alluxio.grpc.UnmountPRequest
-
- hashCode() - Method in class alluxio.grpc.UnmountPResponse
-
- hashCode() - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
- hashCode() - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
- hashCode() - Method in class alluxio.grpc.UpdateMountPRequest
-
- hashCode() - Method in class alluxio.grpc.UpdateMountPResponse
-
- hashCode() - Method in class alluxio.grpc.UpdateUfsModePOptions
-
- hashCode() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
- hashCode() - Method in class alluxio.grpc.UpdateUfsModePResponse
-
- hashCode() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
Deprecated.
- hashCode() - Method in class alluxio.grpc.UploadSnapshotPResponse
-
Deprecated.
- hashCode() - Method in class alluxio.grpc.WorkerIdentity
-
- hashCode() - Method in class alluxio.grpc.WorkerInfo
-
- hashCode() - Method in class alluxio.grpc.WorkerLostStorageInfo
-
- hashCode() - Method in class alluxio.grpc.WorkerNetAddress
-
- hashCode() - Method in class alluxio.grpc.WriteOptions
-
- hashCode() - Method in class alluxio.grpc.WriteRequest
-
- hashCode() - Method in class alluxio.grpc.WriteRequestCommand
-
- hashCode() - Method in class alluxio.grpc.WriteResponse
-
- hashCode() - Method in class alluxio.hadoop.AlluxioFileStatus
-
- hashCode() - Method in class alluxio.heartbeat.CronExpressionIntervalSupplier
-
- hashCode() - Method in class alluxio.heartbeat.FixedIntervalSupplier
-
- hashCode() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
-
- hashCode() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
-
- hashCode() - Method in class alluxio.job.JobDescription
-
- hashCode() - Method in class alluxio.job.plan.BatchedJobConfig
-
- hashCode() - Method in class alluxio.job.plan.meta.PlanInfo
-
- hashCode() - Method in class alluxio.job.plan.migrate.MigrateCommand
-
- hashCode() - Method in class alluxio.job.plan.migrate.MigrateConfig
-
- hashCode() - Method in class alluxio.job.plan.NoopPlanConfig
-
- hashCode() - Method in class alluxio.job.plan.persist.PersistConfig
-
- hashCode() - Method in class alluxio.job.plan.replicate.MoveConfig
-
- hashCode() - Method in class alluxio.job.wire.JobServiceSummary
-
- hashCode() - Method in class alluxio.job.wire.JobWorkerHealth
-
- hashCode() - Method in class alluxio.job.wire.PlanInfo
-
- hashCode() - Method in class alluxio.job.wire.SimpleJobStatusBlock
-
- hashCode() - Method in class alluxio.job.wire.StatusSummary
-
- hashCode() - Method in class alluxio.job.wire.TaskInfo
-
- hashCode() - Method in class alluxio.job.wire.WorkflowInfo
-
- hashCode() - Method in class alluxio.job.workflow.composite.CompositeConfig
-
- hashCode() - Method in class alluxio.master.backcompat.Version
-
- hashCode() - Method in class alluxio.master.block.meta.MasterBlockLocation
-
- hashCode() - Method in class alluxio.master.file.meta.Edge
-
- hashCode() - Method in class alluxio.master.file.meta.Inode
-
- hashCode() - Method in class alluxio.master.file.meta.MutableInode
-
- hashCode() - Method in class alluxio.master.file.meta.options.MountInfo
-
- hashCode() - Method in class alluxio.master.file.meta.TtlBucket
-
- hashCode() - Method in class alluxio.master.file.PersistJob
-
- hashCode() - Method in class alluxio.master.job.CopyJob
-
- hashCode() - Method in class alluxio.master.job.DoraLoadJob
-
- hashCode() - Method in class alluxio.master.job.LoadJob
-
- hashCode() - Method in class alluxio.master.job.MoveJob
-
- hashCode() - Method in class alluxio.master.job.plan.PlanCoordinator
-
- hashCode() - Method in class alluxio.master.journal.options.JournalReaderOptions
-
- hashCode() - Method in class alluxio.master.journal.options.JournalWriterOptions
-
- hashCode() - Method in class alluxio.master.journal.ufs.UfsJournalFile
-
- hashCode() - Method in interface alluxio.master.MasterInquireClient.ConnectDetails
-
- hashCode() - Method in class alluxio.master.metrics.MetricsStore.ClusterCounterKey
-
- hashCode() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
-
- hashCode() - Method in class alluxio.master.predicate.interval.Interval
-
- hashCode() - Method in class alluxio.master.scheduler.Scheduler.WorkerInfoIdentity
-
- hashCode() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
-
- hashCode() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
-
- hashCode() - Method in class alluxio.membership.WorkerServiceEntity
-
- hashCode() - Method in class alluxio.metrics.Metric
-
- hashCode() - Method in class alluxio.metrics.MetricKey
-
- hashCode() - Method in class alluxio.metrics.MetricsFilter
-
- hashCode() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
- hashCode() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.Response
-
- hashCode() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
- hashCode() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
-
- hashCode() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
- hashCode() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.NewBlockEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.RenameEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.SetAclEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.StringPairEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- hashCode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
- hashCode() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
- hashCode() - Method in class alluxio.proto.journal.Job.FileFilter
-
- hashCode() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
- hashCode() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
- hashCode() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
- hashCode() - Method in class alluxio.proto.journal.Journal.JournalOpPId
-
- hashCode() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
- hashCode() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
- hashCode() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
-
- hashCode() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
- hashCode() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
-
- hashCode() - Method in class alluxio.proto.meta.Block.BlockLocation
-
- hashCode() - Method in class alluxio.proto.meta.Block.BlockMeta
-
- hashCode() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
-
- hashCode() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
- hashCode() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
- hashCode() - Method in class alluxio.proto.shared.Acl.AclActions
-
- hashCode() - Method in class alluxio.proto.shared.Acl.AclEntry
-
- hashCode() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
- hashCode() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- hashCode() - Method in class alluxio.proxy.s3.MultipartUploadCleaner.AbortTask
-
- hashCode() - Method in class alluxio.s3.ListBucketOptions
-
- hashCode() - Method in class alluxio.s3.ListBucketResult.CommonPrefix
-
- hashCode() - Method in class alluxio.scheduler.job.Task
-
- hashCode() - Method in class alluxio.security.authorization.AccessControlList
-
- hashCode() - Method in class alluxio.security.authorization.AclActions
-
- hashCode() - Method in class alluxio.security.authorization.AclEntry
-
- hashCode() - Method in class alluxio.security.authorization.DefaultAccessControlList
-
- hashCode() - Method in class alluxio.security.authorization.ExtendedACLEntries
-
- hashCode() - Method in class alluxio.security.authorization.Mode
-
- hashCode() - Method in class alluxio.security.CurrentUser
-
- hashCode() - Method in class alluxio.security.user.BaseUserState
-
- hashCode() - Method in class alluxio.security.User
-
- hashCode() - Method in class alluxio.SessionInfo
-
- hashCode() - Method in class alluxio.stress.job.StressBenchConfig
-
- hashCode() - Method in class alluxio.stress.worker.IOTaskResult.Point
-
- hashCode() - Method in class alluxio.underfs.AbstractUfsManager.Key
-
- hashCode() - Method in class alluxio.underfs.options.CreateOptions
-
- hashCode() - Method in class alluxio.underfs.options.DeleteOptions
-
- hashCode() - Method in class alluxio.underfs.options.FileLocationOptions
-
- hashCode() - Method in class alluxio.underfs.options.ListOptions
-
- hashCode() - Method in class alluxio.underfs.options.MkdirsOptions
-
- hashCode() - Method in class alluxio.underfs.options.OpenOptions
-
- hashCode() - Method in class alluxio.underfs.UfsStatus
-
- hashCode() - Method in class alluxio.uri.EmbeddedLogicalAuthority
-
- hashCode() - Method in class alluxio.uri.MultiMasterAuthority
-
- hashCode() - Method in class alluxio.uri.MultiPartSchemeURI
-
- hashCode() - Method in class alluxio.uri.NoAuthority
-
- hashCode() - Method in class alluxio.uri.SingleMasterAuthority
-
- hashCode() - Method in class alluxio.uri.StandardURI
-
- hashCode() - Method in class alluxio.uri.UnknownAuthority
-
- hashCode() - Method in class alluxio.uri.ZookeeperAuthority
-
- hashCode() - Method in class alluxio.uri.ZookeeperLogicalAuthority
-
- hashCode() - Method in class alluxio.util.UnixMountInfo
-
- hashCode() - Method in class alluxio.util.UnixMountInfo.Options
-
- hashCode() - Method in class alluxio.util.WaitForOptions
-
- hashCode() - Method in class alluxio.util.webui.NodeInfo
-
- hashCode() - Method in class alluxio.wire.Address
-
- hashCode() - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- hashCode() - Method in class alluxio.wire.AlluxioJobWorkerInfo
-
- hashCode() - Method in class alluxio.wire.AlluxioMasterInfo
-
- hashCode() - Method in class alluxio.wire.AlluxioProxyInfo
-
- hashCode() - Method in class alluxio.wire.AlluxioWorkerInfo
-
- hashCode() - Method in class alluxio.wire.BlockInfo
-
- hashCode() - Method in class alluxio.wire.BlockLocation
-
- hashCode() - Method in class alluxio.wire.BlockMasterInfo
-
- hashCode() - Method in class alluxio.wire.Capacity
-
- hashCode() - Method in class alluxio.wire.ConfigHash
-
- hashCode() - Method in class alluxio.wire.FileBlockInfo
-
- hashCode() - Method in class alluxio.wire.FileInfo
-
- hashCode() - Method in class alluxio.wire.InconsistentProperty
-
- hashCode() - Method in class alluxio.wire.MasterInfo
-
- hashCode() - Method in class alluxio.wire.MountPointInfo
-
- hashCode() - Method in class alluxio.wire.WorkerIdentity
-
- hashCode() - Method in class alluxio.wire.WorkerInfo
-
- hashCode() - Method in class alluxio.wire.WorkerNetAddress
-
- hashCode() - Method in class alluxio.worker.block.AllocateOptions
-
- hashCode() - Method in class alluxio.worker.block.BlockStoreLocation
-
- hashCode() - Method in class alluxio.worker.block.CreateBlockOptions
-
- hasHigh() - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value high = 2;
- hasHigh() - Method in class alluxio.grpc.table.Range
-
optional .alluxio.grpc.table.Value high = 2;
- hasHigh() - Method in interface alluxio.grpc.table.RangeOrBuilder
-
optional .alluxio.grpc.table.Value high = 2;
- hasHighValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date high_value = 2;
- hasHighValue() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional .alluxio.grpc.table.Date high_value = 2;
- hasHighValue() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Date high_value = 2;
- hasHighValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- hasHighValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- hasHighValue() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- hasHighValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional double high_value = 2;
- hasHighValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional double high_value = 2;
- hasHighValue() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional double high_value = 2;
- hasHighValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 high_value = 2;
- hasHighValue() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional int64 high_value = 2;
- hasHighValue() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional int64 high_value = 2;
- hashIgnoreCase(int, String) - Static method in class alluxio.util.URIUtils
-
Hashes a string for a URI hash, while ignoring the case.
- hasHiveLayout(Partition) - Static method in class alluxio.table.ProtoUtils
-
- hasHost() - Method in class alluxio.grpc.NetAddress.Builder
-
optional string host = 1;
- hasHost() - Method in class alluxio.grpc.NetAddress
-
optional string host = 1;
- hasHost() - Method in interface alluxio.grpc.NetAddressOrBuilder
-
optional string host = 1;
- hasHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string host = 1;
- hasHost() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string host = 1;
- hasHost() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string host = 1;
- hasHostname() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional string hostname = 4;
- hasHostname() - Method in class alluxio.grpc.JobWorkerHealth
-
optional string hostname = 4;
- hasHostname() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional string hostname = 4;
- HashUtils - Class in alluxio.util
-
Util class for hashing.
- hasId() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.grpc.GetNewBlockIdForFilePResponseOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.grpc.JobInfo
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.grpc.PolicyInfo
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.grpc.RegisterJobWorkerPResponseOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional uint32 id = 1;
- hasId() - Method in class alluxio.grpc.table.FieldSchema
-
optional uint32 id = 1;
- hasId() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional uint32 id = 1;
- hasId() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.grpc.WorkerInfo
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
The block ID or UFS file ID.
- hasId() - Method in class alluxio.grpc.WriteRequestCommand
-
The block ID or UFS file ID.
- hasId() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
The block ID or UFS file ID.
- hasId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
The block ID or UFS file ID.
- hasId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
The block ID or UFS file ID.
- hasId() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
The block ID or UFS file ID.
- hasId() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 id = 2;
- hasId() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
optional int64 id = 2;
- hasId() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
optional int64 id = 2;
- hasId() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.NewBlockEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.NewBlockEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.PersistDirectoryEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.SetAclEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 id = 1;
- hasId() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 id = 1;
- hasId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 id = 1;
- hasIdentifier() - Method in class alluxio.grpc.WorkerIdentity.Builder
-
exactly how this byte sequence is interpreted depends on the version of its definition
- hasIdentifier() - Method in class alluxio.grpc.WorkerIdentity
-
exactly how this byte sequence is interpreted depends on the version of its definition
- hasIdentifier() - Method in interface alluxio.grpc.WorkerIdentityOrBuilder
-
exactly how this byte sequence is interpreted depends on the version of its definition
- hasIgnoreClusterConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool ignoreClusterConf = 2;
- hasIgnoreClusterConf() - Method in class alluxio.grpc.GetConfigurationPOptions
-
optional bool ignoreClusterConf = 2;
- hasIgnoreClusterConf() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
-
optional bool ignoreClusterConf = 2;
- hasIgnorePathConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool ignorePathConf = 3;
- hasIgnorePathConf() - Method in class alluxio.grpc.GetConfigurationPOptions
-
optional bool ignorePathConf = 3;
- hasIgnorePathConf() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
-
optional bool ignorePathConf = 3;
- hasIgnoreSyncErrors() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional bool ignore_sync_errors = 6;
- hasIgnoreSyncErrors() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional bool ignore_sync_errors = 6;
- hasIgnoreSyncErrors() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional bool ignore_sync_errors = 6;
- hasInAlluxioPercentage() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 inAlluxioPercentage = 24;
- hasInAlluxioPercentage() - Method in class alluxio.grpc.FileInfo
-
optional int32 inAlluxioPercentage = 24;
- hasInAlluxioPercentage() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int32 inAlluxioPercentage = 24;
- hasIncludeRealContentHash() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional bool includeRealContentHash = 5;
- hasIncludeRealContentHash() - Method in class alluxio.grpc.GetStatusPOptions
-
optional bool includeRealContentHash = 5;
- hasIncludeRealContentHash() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional bool includeRealContentHash = 5;
- hasInMemoryPercentage() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 inMemoryPercentage = 25;
- hasInMemoryPercentage() - Method in class alluxio.grpc.FileInfo
-
optional int32 inMemoryPercentage = 25;
- hasInMemoryPercentage() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int32 inMemoryPercentage = 25;
- hasInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- hasInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- hasInodeDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- hasInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- hasInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- hasInodeDirectoryIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- hasInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- hasInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- hasInodeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- hasInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- hasInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- hasInodeLastModificationTime() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- hasInputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string input_format = 2;
- hasInputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
optional string input_format = 2;
- hasInputFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
optional string input_format = 2;
- hasInstance() - Method in class alluxio.grpc.Metric.Builder
-
optional string instance = 1;
- hasInstance() - Method in class alluxio.grpc.Metric
-
optional string instance = 1;
- hasInstance() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional string instance = 1;
- hasIsAtomicWrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool isAtomicWrite = 16;
- hasIsAtomicWrite() - Method in class alluxio.grpc.CreateFilePOptions
-
optional bool isAtomicWrite = 16;
- hasIsAtomicWrite() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional bool isAtomicWrite = 16;
- hasIsCacheable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_cacheable = 17;
- hasIsCacheable() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional bool is_cacheable = 17;
- hasIsCacheable() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional bool is_cacheable = 17;
- hasIsCompleted() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_completed = 18;
- hasIsCompleted() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional bool is_completed = 18;
- hasIsCompleted() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional bool is_completed = 18;
- hasIsDefault() - Method in class alluxio.grpc.PAcl.Builder
-
optional bool isDefault = 5;
- hasIsDefault() - Method in class alluxio.grpc.PAcl
-
optional bool isDefault = 5;
- hasIsDefault() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional bool isDefault = 4;
- hasIsDefault() - Method in class alluxio.grpc.PAclEntry
-
optional bool isDefault = 4;
- hasIsDefault() - Method in interface alluxio.grpc.PAclEntryOrBuilder
-
optional bool isDefault = 4;
- hasIsDefault() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional bool isDefault = 5;
- hasIsDefault() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional bool isDefault = 7;
- hasIsDefault() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional bool isDefault = 7;
- hasIsDefault() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional bool isDefault = 7;
- hasIsDefault() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional bool isDefault = 4;
- hasIsDefault() - Method in class alluxio.proto.shared.Acl.AclEntry
-
optional bool isDefault = 4;
- hasIsDefault() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
-
optional bool isDefault = 4;
- hasIsDefaultEmpty() - Method in class alluxio.grpc.PAcl.Builder
-
optional bool isDefaultEmpty = 6;
- hasIsDefaultEmpty() - Method in class alluxio.grpc.PAcl
-
optional bool isDefaultEmpty = 6;
- hasIsDefaultEmpty() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional bool isDefaultEmpty = 6;
- hasIsDirectory() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional bool is_directory = 2;
- hasIsDirectory() - Method in class alluxio.grpc.UfsStatus
-
optional bool is_directory = 2;
- hasIsDirectory() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional bool is_directory = 2;
- hasIsDirectory() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_directory = 3;
- hasIsDirectory() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional bool is_directory = 3;
- hasIsDirectory() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional bool is_directory = 3;
- hasIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional bool isEmpty = 8;
- hasIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional bool isEmpty = 8;
- hasIsEmpty() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional bool isEmpty = 8;
- hasIsLeader() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional bool isLeader = 3;
- hasIsLeader() - Method in class alluxio.grpc.QuorumServerInfo
-
optional bool isLeader = 3;
- hasIsLeader() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
-
optional bool isLeader = 3;
- hasIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
directory only
- hasIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
directory only
- hasIsMountPoint() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
directory only
- hasIsMultipartUpload() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
optional bool isMultipartUpload = 2;
- hasIsMultipartUpload() - Method in class alluxio.grpc.S3SyntaxOptions
-
optional bool isMultipartUpload = 2;
- hasIsMultipartUpload() - Method in interface alluxio.grpc.S3SyntaxOptionsOrBuilder
-
optional bool isMultipartUpload = 2;
- hasIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_pinned = 9;
- hasIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional bool is_pinned = 9;
- hasIsPinned() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional bool is_pinned = 9;
- hasIsRetryable() - Method in class alluxio.grpc.RetryInfo.Builder
-
optional bool isRetryable = 1;
- hasIsRetryable() - Method in class alluxio.grpc.RetryInfo
-
optional bool isRetryable = 1;
- hasIsRetryable() - Method in interface alluxio.grpc.RetryInfoOrBuilder
-
optional bool isRetryable = 1;
- hasIsScanning() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional bool isScanning = 11;
- hasIsScanning() - Method in class alluxio.grpc.PolicyStatus
-
optional bool isScanning = 11;
- hasIsScanning() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional bool isScanning = 11;
- hasIsSkip() - Method in class alluxio.grpc.RouteFailure.Builder
-
optional bool is_skip = 5;
- hasIsSkip() - Method in class alluxio.grpc.RouteFailure
-
optional bool is_skip = 5;
- hasIsSkip() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
optional bool is_skip = 5;
- hasIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
optional bool isThrowable = 2;
- hasIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader
-
optional bool isThrowable = 2;
- hasIsThrowable() - Method in interface alluxio.grpc.MessagingResponseHeaderOrBuilder
-
optional bool isThrowable = 2;
- hasIsTruncated() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
True if the partial listing was truncated.
- hasIsTruncated() - Method in class alluxio.grpc.ListStatusPartialPResponse
-
True if the partial listing was truncated.
- hasIsTruncated() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
-
True if the partial listing was truncated.
- hasJobConfig() - Method in class alluxio.grpc.RunPRequest.Builder
-
optional bytes jobConfig = 1;
- hasJobConfig() - Method in class alluxio.grpc.RunPRequest
-
optional bytes jobConfig = 1;
- hasJobConfig() - Method in interface alluxio.grpc.RunPRequestOrBuilder
-
optional bytes jobConfig = 1;
- hasJobConfig() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional bytes jobConfig = 3;
- hasJobConfig() - Method in class alluxio.grpc.RunTaskCommand
-
optional bytes jobConfig = 3;
- hasJobConfig() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
-
optional bytes jobConfig = 3;
- hasJobControlId() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in class alluxio.grpc.CmdStatusBlock
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in class alluxio.grpc.CmdSummary
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in interface alluxio.grpc.GetCmdStatusDetailedRequestOrBuilder
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in class alluxio.grpc.GetCmdStatusRequest
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in interface alluxio.grpc.GetCmdStatusRequestOrBuilder
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in class alluxio.grpc.SubmitResponse.Builder
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in class alluxio.grpc.SubmitResponse
-
optional int64 jobControlId = 1;
- hasJobControlId() - Method in interface alluxio.grpc.SubmitResponseOrBuilder
-
optional int64 jobControlId = 1;
- hasJobDescription() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- hasJobDescription() - Method in class alluxio.grpc.GetJobProgressPRequest
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- hasJobDescription() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- hasJobDescription() - Method in class alluxio.grpc.StopJobPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- hasJobDescription() - Method in class alluxio.grpc.StopJobPRequest
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- hasJobDescription() - Method in interface alluxio.grpc.StopJobPRequestOrBuilder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- hasJobError() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string job_error = 6;
- hasJobError() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string job_error = 6;
- hasJobError() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string job_error = 6;
- hasJobId() - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.CancelPRequest
-
optional int64 jobId = 1;
- hasJobId() - Method in interface alluxio.grpc.CancelPRequestOrBuilder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.CancelTaskCommand
-
optional int64 jobId = 1;
- hasJobId() - Method in interface alluxio.grpc.CancelTaskCommandOrBuilder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
optional int64 jobId = 1;
- hasJobId() - Method in interface alluxio.grpc.GetJobStatusDetailedPRequestOrBuilder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.GetJobStatusPRequest
-
optional int64 jobId = 1;
- hasJobId() - Method in interface alluxio.grpc.GetJobStatusPRequestOrBuilder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.JobProgress
-
optional int64 jobId = 1;
- hasJobId() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.JobStatusBlock
-
optional int64 jobId = 1;
- hasJobId() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.RunPResponse.Builder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.RunPResponse
-
optional int64 jobId = 1;
- hasJobId() - Method in interface alluxio.grpc.RunPResponseOrBuilder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.RunTaskCommand
-
optional int64 jobId = 1;
- hasJobId() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
-
optional int64 jobId = 1;
- hasJobId() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
optional string jobId = 1;
- hasJobId() - Method in class alluxio.grpc.SubmitJobPResponse
-
optional string jobId = 1;
- hasJobId() - Method in interface alluxio.grpc.SubmitJobPResponseOrBuilder
-
optional string jobId = 1;
- hasJobId() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
optional int64 job_id = 1;
- hasJobId() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
-
optional int64 job_id = 1;
- hasJobId() - Method in interface alluxio.grpc.table.GetTransformJobInfoPRequestOrBuilder
-
optional int64 job_id = 1;
- hasJobId() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional int64 job_id = 4;
- hasJobId() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional int64 job_id = 4;
- hasJobId() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional int64 job_id = 4;
- hasJobId() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
optional int64 job_id = 1;
- hasJobId() - Method in class alluxio.grpc.table.TransformTablePResponse
-
optional int64 job_id = 1;
- hasJobId() - Method in interface alluxio.grpc.table.TransformTablePResponseOrBuilder
-
optional int64 job_id = 1;
- hasJobId() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string job_id = 8;
- hasJobId() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required string job_id = 8;
- hasJobId() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required string job_id = 8;
- hasJobId() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string job_id = 7;
- hasJobId() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required string job_id = 7;
- hasJobId() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required string job_id = 7;
- hasJobId() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string job_id = 8;
- hasJobId() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required string job_id = 8;
- hasJobId() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required string job_id = 8;
- hasJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional bool jobIdOnly = 3;
- hasJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions
-
optional bool jobIdOnly = 3;
- hasJobIdOnly() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
-
optional bool jobIdOnly = 3;
- hasJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- hasJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- hasJobInfo() - Method in interface alluxio.grpc.GetJobStatusDetailedPResponseOrBuilder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- hasJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- hasJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- hasJobInfo() - Method in interface alluxio.grpc.GetJobStatusPResponseOrBuilder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- hasJobMasterId() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional int64 jobMasterId = 1;
- hasJobMasterId() - Method in class alluxio.grpc.RegisterJobMasterPRequest
-
optional int64 jobMasterId = 1;
- hasJobMasterId() - Method in interface alluxio.grpc.RegisterJobMasterPRequestOrBuilder
-
optional int64 jobMasterId = 1;
- hasJobSource() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.JobSource jobSource = 3;
- hasJobSource() - Method in class alluxio.grpc.CmdSummary
-
optional .alluxio.grpc.job.JobSource jobSource = 3;
- hasJobSource() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional .alluxio.grpc.job.JobSource jobSource = 3;
- hasJobStatus() - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional .alluxio.grpc.job.Status jobStatus = 2;
- hasJobStatus() - Method in class alluxio.grpc.JobStatusBlock
-
optional .alluxio.grpc.job.Status jobStatus = 2;
- hasJobStatus() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
-
optional .alluxio.grpc.job.Status jobStatus = 2;
- hasJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional .alluxio.grpc.job.Status job_status = 5;
- hasJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional .alluxio.grpc.job.Status job_status = 5;
- hasJobStatus() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional .alluxio.grpc.job.Status job_status = 5;
- hasJobStopped() - Method in class alluxio.grpc.StopJobPResponse.Builder
-
optional bool jobStopped = 1;
- hasJobStopped() - Method in class alluxio.grpc.StopJobPResponse
-
optional bool jobStopped = 1;
- hasJobStopped() - Method in interface alluxio.grpc.StopJobPResponseOrBuilder
-
optional bool jobStopped = 1;
- hasJobWorkerHealth() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- hasJobWorkerHealth() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- hasJobWorkerHealth() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- hasJournalEntriesSinceCheckpoint() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
optional int64 journalEntriesSinceCheckpoint = 2;
- hasJournalEntriesSinceCheckpoint() - Method in class alluxio.grpc.MasterHeartbeatPOptions
-
optional int64 journalEntriesSinceCheckpoint = 2;
- hasJournalEntriesSinceCheckpoint() - Method in interface alluxio.grpc.MasterHeartbeatPOptionsOrBuilder
-
optional int64 journalEntriesSinceCheckpoint = 2;
- hasKey() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- hasKey() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- hasKey() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- hasKey() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string key = 1;
- hasKey() - Method in class alluxio.proto.journal.File.StringPairEntry
-
optional string key = 1;
- hasKey() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
-
optional string key = 1;
- hasLastAccessedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 last_accessed_ms = 30;
- hasLastAccessedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 last_accessed_ms = 30;
- hasLastAccessedMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 last_accessed_ms = 30;
- hasLastAccessTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 lastAccessTimeMs = 31;
- hasLastAccessTimeMs() - Method in class alluxio.grpc.FileInfo
-
optional int64 lastAccessTimeMs = 31;
- hasLastAccessTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 lastAccessTimeMs = 31;
- hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 last_access_time_ms = 20;
- hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 last_access_time_ms = 20;
- hasLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 last_access_time_ms = 20;
- hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 last_access_time_ms = 29;
- hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 last_access_time_ms = 29;
- hasLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 last_access_time_ms = 29;
- hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 last_access_time_ms = 18;
- hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 last_access_time_ms = 18;
- hasLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 last_access_time_ms = 18;
- hasLastCheckpointTime() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
optional int64 lastCheckpointTime = 1;
- hasLastCheckpointTime() - Method in class alluxio.grpc.MasterHeartbeatPOptions
-
optional int64 lastCheckpointTime = 1;
- hasLastCheckpointTime() - Method in interface alluxio.grpc.MasterHeartbeatPOptionsOrBuilder
-
optional int64 lastCheckpointTime = 1;
- hasLastContactSec() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int32 lastContactSec = 3;
- hasLastContactSec() - Method in class alluxio.grpc.WorkerInfo
-
optional int32 lastContactSec = 3;
- hasLastContactSec() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional int32 lastContactSec = 3;
- hasLastHeartbeatTime() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional int64 lastHeartbeatTime = 4;
- hasLastHeartbeatTime() - Method in class alluxio.grpc.ProxyStatus
-
optional int64 lastHeartbeatTime = 4;
- hasLastHeartbeatTime() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional int64 lastHeartbeatTime = 4;
- hasLastModificationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 lastModificationTimeMs = 14;
- hasLastModificationTimeMs() - Method in class alluxio.grpc.FileInfo
-
optional int64 lastModificationTimeMs = 14;
- hasLastModificationTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 lastModificationTimeMs = 14;
- hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 last_modification_time_ms = 7;
- hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 last_modification_time_ms = 7;
- hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 last_modification_time_ms = 7;
- hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 last_modification_time_ms = 7;
- hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
optional int64 last_modification_time_ms = 2;
- hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
-
optional int64 last_modification_time_ms = 2;
- hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
-
optional int64 last_modification_time_ms = 2;
- hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 last_modification_time_ms = 7;
- hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 last_modification_time_ms = 7;
- hasLastModifiedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 last_modified_ms = 25;
- hasLastModifiedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 last_modified_ms = 25;
- hasLastModifiedMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 last_modified_ms = 25;
- hasLastModifiedTimeMs() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional int64 last_modified_time_ms = 3;
- hasLastModifiedTimeMs() - Method in class alluxio.grpc.UfsStatus
-
optional int64 last_modified_time_ms = 3;
- hasLastModifiedTimeMs() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional int64 last_modified_time_ms = 3;
- hasLastUpdated() - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 lastUpdated = 6;
- hasLastUpdated() - Method in class alluxio.grpc.JobInfo
-
optional int64 lastUpdated = 6;
- hasLastUpdated() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional int64 lastUpdated = 6;
- hasLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int64 lastUpdated = 3;
- hasLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth
-
optional int64 lastUpdated = 3;
- hasLastUpdated() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional int64 lastUpdated = 3;
- hasLastUpdatedTime() - Method in class alluxio.grpc.ActionInfo.Builder
-
optional int64 lastUpdatedTime = 5;
- hasLastUpdatedTime() - Method in class alluxio.grpc.ActionInfo
-
optional int64 lastUpdatedTime = 5;
- hasLastUpdatedTime() - Method in interface alluxio.grpc.ActionInfoOrBuilder
-
optional int64 lastUpdatedTime = 5;
- hasLastUpdateMs() - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 lastUpdateMs = 4;
- hasLastUpdateMs() - Method in class alluxio.grpc.JobProgress
-
optional int64 lastUpdateMs = 4;
- hasLastUpdateMs() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional int64 lastUpdateMs = 4;
- hasLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- hasLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse
-
Deprecated.
- hasLatest() - Method in interface alluxio.grpc.GetSnapshotInfoResponseOrBuilder
-
Deprecated.
- hasLayout() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Layout layout = 6;
- hasLayout() - Method in class alluxio.grpc.table.TableInfo
-
optional .alluxio.grpc.table.Layout layout = 6;
- hasLayout() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional .alluxio.grpc.table.Layout layout = 6;
- hasLayout() - Method in class alluxio.grpc.table.Transformation.Builder
-
optional .alluxio.grpc.table.Layout layout = 1;
- hasLayout() - Method in class alluxio.grpc.table.Transformation
-
optional .alluxio.grpc.table.Layout layout = 1;
- hasLayout() - Method in interface alluxio.grpc.table.TransformationOrBuilder
-
optional .alluxio.grpc.table.Layout layout = 1;
- hasLayoutData() - Method in class alluxio.grpc.table.Layout.Builder
-
optional bytes layout_data = 3;
- hasLayoutData() - Method in class alluxio.grpc.table.Layout
-
optional bytes layout_data = 3;
- hasLayoutData() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
optional bytes layout_data = 3;
- hasLayoutSpec() - Method in class alluxio.grpc.table.Layout.Builder
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- hasLayoutSpec() - Method in class alluxio.grpc.table.Layout
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- hasLayoutSpec() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- hasLayoutType() - Method in class alluxio.grpc.table.Layout.Builder
-
optional string layout_type = 1;
- hasLayoutType() - Method in class alluxio.grpc.table.Layout
-
optional string layout_type = 1;
- hasLayoutType() - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
optional string layout_type = 1;
- hasLeaderMasterAddress() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string leaderMasterAddress = 1;
- hasLeaderMasterAddress() - Method in class alluxio.grpc.MasterInfo
-
optional string leaderMasterAddress = 1;
- hasLeaderMasterAddress() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional string leaderMasterAddress = 1;
- hasLeastSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
-
optional int64 leastSignificantBits = 2;
- hasLeastSignificantBits() - Method in class alluxio.grpc.FsOpPId
-
optional int64 leastSignificantBits = 2;
- hasLeastSignificantBits() - Method in interface alluxio.grpc.FsOpPIdOrBuilder
-
optional int64 leastSignificantBits = 2;
- hasLeastSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
optional int64 leastSignificantBits = 2;
- hasLeastSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId
-
optional int64 leastSignificantBits = 2;
- hasLeastSignificantBits() - Method in interface alluxio.proto.journal.Journal.JournalOpPIdOrBuilder
-
optional int64 leastSignificantBits = 2;
- hasLength() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int64 length = 5;
- hasLength() - Method in class alluxio.grpc.AsyncCacheRequest
-
optional int64 length = 5;
- hasLength() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
optional int64 length = 5;
- hasLength() - Method in class alluxio.grpc.Block.Builder
-
The block length.
- hasLength() - Method in class alluxio.grpc.Block
-
The block length.
- hasLength() - Method in class alluxio.grpc.BlockInfo.Builder
-
optional int64 length = 2;
- hasLength() - Method in class alluxio.grpc.BlockInfo
-
optional int64 length = 2;
- hasLength() - Method in interface alluxio.grpc.BlockInfoOrBuilder
-
optional int64 length = 2;
- hasLength() - Method in interface alluxio.grpc.BlockOrBuilder
-
The block length.
- hasLength() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int64 length = 5;
- hasLength() - Method in class alluxio.grpc.CacheRequest
-
optional int64 length = 5;
- hasLength() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional int64 length = 5;
- hasLength() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the length of the block being committed
- hasLength() - Method in class alluxio.grpc.CommitBlockPRequest
-
the length of the block being committed
- hasLength() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the length of the block being committed
- hasLength() - Method in class alluxio.grpc.File.Builder
-
file length
- hasLength() - Method in class alluxio.grpc.File
-
file length
- hasLength() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 length = 5;
- hasLength() - Method in class alluxio.grpc.FileInfo
-
optional int64 length = 5;
- hasLength() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 length = 5;
- hasLength() - Method in interface alluxio.grpc.FileOrBuilder
-
file length
- hasLength() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 length = 3;
- hasLength() - Method in class alluxio.grpc.ReadRequest
-
optional int64 length = 3;
- hasLength() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
optional int64 length = 3;
- hasLength() - Method in class alluxio.grpc.Route.Builder
-
optional int64 length = 3;
- hasLength() - Method in class alluxio.grpc.Route
-
optional int64 length = 3;
- hasLength() - Method in interface alluxio.grpc.RouteOrBuilder
-
optional int64 length = 3;
- hasLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int64 length = 5;
- hasLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
optional int64 length = 5;
- hasLength() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
optional int64 length = 5;
- hasLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 length = 3;
- hasLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
optional int64 length = 3;
- hasLength() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
optional int64 length = 3;
- hasLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional int64 length = 2;
- hasLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
optional int64 length = 2;
- hasLength() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
-
optional int64 length = 2;
- hasLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 length = 3;
- hasLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
optional int64 length = 3;
- hasLength() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
optional int64 length = 3;
- hasLength() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 length = 9;
- hasLength() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 length = 9;
- hasLength() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 length = 9;
- hasLength() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 length = 2;
- hasLength() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
optional int64 length = 2;
- hasLength() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
-
optional int64 length = 2;
- hasLength() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 length = 3;
- hasLength() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int64 length = 3;
- hasLength() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int64 length = 3;
- hasLength() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
optional int64 length = 1;
- hasLength() - Method in class alluxio.proto.meta.Block.BlockMeta
-
optional int64 length = 1;
- hasLength() - Method in interface alluxio.proto.meta.Block.BlockMetaOrBuilder
-
optional int64 length = 1;
- hasLength() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 length = 19;
- hasLength() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 length = 19;
- hasLength() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 length = 19;
- hasLiveWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 liveWorkerNum = 4;
- hasLiveWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int32 liveWorkerNum = 4;
- hasLiveWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int32 liveWorkerNum = 4;
- hasLoadDescendantType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
- hasLoadDescendantType() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
- hasLoadDescendantType() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
- hasLoadDirectChildren() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
This is deprecated since 1.1.1 and will be removed in 2.0.
- hasLoadDirectChildren() - Method in class alluxio.grpc.ListStatusPOptions
-
This is deprecated since 1.1.1 and will be removed in 2.0.
- hasLoadDirectChildren() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
This is deprecated since 1.1.1 and will be removed in 2.0.
- hasLoadJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- hasLoadJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- hasLoadJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- hasLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
No data will be transferred.
- hasLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions
-
No data will be transferred.
- hasLoadMetadataOnly() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
No data will be transferred.
- hasLoadMetadataOnly() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
If set false, only the metadata of file will be loaded.
- hasLoadMetadataOnly() - Method in class alluxio.grpc.LoadFileRequest
-
If set false, only the metadata of file will be loaded.
- hasLoadMetadataOnly() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
If set false, only the metadata of file will be loaded.
- hasLoadMetadataOnly() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool loadMetadataOnly = 4;
- hasLoadMetadataOnly() - Method in class alluxio.grpc.LoadJobPOptions
-
optional bool loadMetadataOnly = 4;
- hasLoadMetadataOnly() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
-
optional bool loadMetadataOnly = 4;
- hasLoadMetadataOnly() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional bool load_metadata_only = 9;
- hasLoadMetadataOnly() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional bool load_metadata_only = 9;
- hasLoadMetadataOnly() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional bool load_metadata_only = 9;
- hasLoadMetadataType() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- hasLoadMetadataType() - Method in class alluxio.grpc.ExistsPOptions
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- hasLoadMetadataType() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- hasLoadMetadataType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- hasLoadMetadataType() - Method in class alluxio.grpc.GetStatusPOptions
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- hasLoadMetadataType() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- hasLoadMetadataType() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
- hasLoadMetadataType() - Method in class alluxio.grpc.ListStatusPOptions
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
- hasLoadMetadataType() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
- hasLoadPath() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string load_path = 1;
- hasLoadPath() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required string load_path = 1;
- hasLoadPath() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required string load_path = 1;
- hasLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
- hasLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
- hasLoadType() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
- hasLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool localFileSystem = 1;
- hasLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions
-
optional bool localFileSystem = 1;
- hasLocalFileSystem() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
-
optional bool localFileSystem = 1;
- hasLocation() - Method in class alluxio.grpc.table.Database.Builder
-
optional string location = 3;
- hasLocation() - Method in class alluxio.grpc.table.Database
-
optional string location = 3;
- hasLocation() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string location = 3;
- hasLocation() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional string location = 2;
- hasLocation() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional string location = 2;
- hasLocation() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional string location = 2;
- hasLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- hasLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- hasLongStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- hasLongType() - Method in class alluxio.grpc.table.Value.Builder
-
int64 long_type = 1;
- hasLongType() - Method in class alluxio.grpc.table.Value
-
int64 long_type = 1;
- hasLongType() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
int64 long_type = 1;
- hasLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional int64 losePrimacyTimeMs = 3;
- hasLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
optional int64 losePrimacyTimeMs = 3;
- hasLosePrimacyTimeMs() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
-
optional int64 losePrimacyTimeMs = 3;
- hasLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional int64 losePrimacyTimeMs = 3;
- hasLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions
-
optional int64 losePrimacyTimeMs = 3;
- hasLosePrimacyTimeMs() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
optional int64 losePrimacyTimeMs = 3;
- hasLostStorage() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
- hasLostWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 lostWorkerNum = 5;
- hasLostWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int32 lostWorkerNum = 5;
- hasLostWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int32 lostWorkerNum = 5;
- hasLow() - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value low = 1;
- hasLow() - Method in class alluxio.grpc.table.Range
-
optional .alluxio.grpc.table.Value low = 1;
- hasLow() - Method in interface alluxio.grpc.table.RangeOrBuilder
-
optional .alluxio.grpc.table.Value low = 1;
- hasLowValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date low_value = 1;
- hasLowValue() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional .alluxio.grpc.table.Date low_value = 1;
- hasLowValue() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Date low_value = 1;
- hasLowValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- hasLowValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- hasLowValue() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- hasLowValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional double low_value = 1;
- hasLowValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional double low_value = 1;
- hasLowValue() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional double low_value = 1;
- hasLowValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 low_value = 1;
- hasLowValue() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional int64 low_value = 1;
- hasLowValue() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional int64 low_value = 1;
- hasMaskActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- hasMaskActions() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- hasMaskActions() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- hasMasterAddress() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- hasMasterAddress() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- hasMasterAddress() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- hasMasterAddress() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- hasMasterAddress() - Method in class alluxio.grpc.GetMasterIdPRequest
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- hasMasterAddress() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- hasMasterAddress() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- hasMasterAddress() - Method in class alluxio.grpc.JobMasterStatus
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- hasMasterAddress() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- hasMasterHostname() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
The hostname of the master that did the checkpoint
- hasMasterHostname() - Method in class alluxio.grpc.CheckpointPResponse
-
The hostname of the master that did the checkpoint
- hasMasterHostname() - Method in interface alluxio.grpc.CheckpointPResponseOrBuilder
-
The hostname of the master that did the checkpoint
- hasMasterId() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
optional int64 masterId = 1;
- hasMasterId() - Method in class alluxio.grpc.GetJobMasterIdPResponse
-
optional int64 masterId = 1;
- hasMasterId() - Method in interface alluxio.grpc.GetJobMasterIdPResponseOrBuilder
-
optional int64 masterId = 1;
- hasMasterId() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
optional int64 masterId = 1;
- hasMasterId() - Method in class alluxio.grpc.GetMasterIdPResponse
-
optional int64 masterId = 1;
- hasMasterId() - Method in interface alluxio.grpc.GetMasterIdPResponseOrBuilder
-
optional int64 masterId = 1;
- hasMasterId() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional int64 masterId = 1;
- hasMasterId() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
optional int64 masterId = 1;
- hasMasterId() - Method in interface alluxio.grpc.JobMasterHeartbeatPRequestOrBuilder
-
optional int64 masterId = 1;
- hasMasterId() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional int64 masterId = 1;
- hasMasterId() - Method in class alluxio.grpc.MasterHeartbeatPRequest
-
optional int64 masterId = 1;
- hasMasterId() - Method in interface alluxio.grpc.MasterHeartbeatPRequestOrBuilder
-
optional int64 masterId = 1;
- hasMasterId() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional int64 masterId = 1;
- hasMasterId() - Method in class alluxio.grpc.RegisterMasterPRequest
-
optional int64 masterId = 1;
- hasMasterId() - Method in interface alluxio.grpc.RegisterMasterPRequestOrBuilder
-
optional int64 masterId = 1;
- hasMasterInfo() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- hasMasterInfo() - Method in class alluxio.grpc.GetMasterInfoPResponse
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- hasMasterInfo() - Method in interface alluxio.grpc.GetMasterInfoPResponseOrBuilder
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- hasMaxColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional int64 max_col_len = 1;
- hasMaxColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
optional int64 max_col_len = 1;
- hasMaxColLen() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
-
optional int64 max_col_len = 1;
- hasMaxColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 max_col_len = 1;
- hasMaxColLen() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional int64 max_col_len = 1;
- hasMaxColLen() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional int64 max_col_len = 1;
- hasMaxUfsReadConcurrency() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional int32 maxUfsReadConcurrency = 2;
- hasMaxUfsReadConcurrency() - Method in class alluxio.grpc.OpenFilePOptions
-
optional int32 maxUfsReadConcurrency = 2;
- hasMaxUfsReadConcurrency() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional int32 maxUfsReadConcurrency = 2;
- hasMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional int32 maxUfsReadConcurrency = 4;
- hasMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
optional int32 maxUfsReadConcurrency = 4;
- hasMaxUfsReadConcurrency() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
optional int32 maxUfsReadConcurrency = 4;
- hasMediumType() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string mediumType = 4;
- hasMediumType() - Method in class alluxio.grpc.BlockLocation
-
optional string mediumType = 4;
- hasMediumType() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional string mediumType = 4;
- hasMediumType() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string mediumType = 2;
- hasMediumType() - Method in class alluxio.grpc.BlockStoreLocationProto
-
optional string mediumType = 2;
- hasMediumType() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
-
optional string mediumType = 2;
- hasMediumType() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional string mediumType = 7;
- hasMediumType() - Method in class alluxio.grpc.CommitBlockPRequest
-
optional string mediumType = 7;
- hasMediumType() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
optional string mediumType = 7;
- hasMediumType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional string medium_type = 2;
- hasMediumType() - Method in class alluxio.grpc.MoveBlockRequest
-
optional string medium_type = 2;
- hasMediumType() - Method in interface alluxio.grpc.MoveBlockRequestOrBuilder
-
optional string medium_type = 2;
- hasMediumType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional string medium_type = 8;
- hasMediumType() - Method in class alluxio.grpc.WriteRequestCommand
-
optional string medium_type = 8;
- hasMediumType() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional string medium_type = 8;
- hasMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string mediumType = 3;
- hasMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation
-
optional string mediumType = 3;
- hasMediumType() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
-
optional string mediumType = 3;
- hasMessage() - Method in class alluxio.grpc.BlockStatus.Builder
-
A developer-facing error message
- hasMessage() - Method in class alluxio.grpc.BlockStatus
-
A developer-facing error message
- hasMessage() - Method in interface alluxio.grpc.BlockStatusOrBuilder
-
A developer-facing error message
- hasMessage() - Method in class alluxio.grpc.FileFailure.Builder
-
A developer-facing error message
- hasMessage() - Method in class alluxio.grpc.FileFailure
-
A developer-facing error message
- hasMessage() - Method in interface alluxio.grpc.FileFailureOrBuilder
-
A developer-facing error message
- hasMessage() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
A developer-facing error message
- hasMessage() - Method in class alluxio.grpc.LoadFileFailure
-
A developer-facing error message
- hasMessage() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
-
A developer-facing error message
- hasMessage() - Method in class alluxio.grpc.RouteFailure.Builder
-
A developer-facing error message
- hasMessage() - Method in class alluxio.grpc.RouteFailure
-
A developer-facing error message
- hasMessage() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
A developer-facing error message
- hasMessage() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional bytes message = 2;
- hasMessage() - Method in class alluxio.grpc.SaslMessage
-
optional bytes message = 2;
- hasMessage() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional bytes message = 2;
- hasMessage() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional bytes message = 3;
- hasMessage() - Method in class alluxio.grpc.TransportMessage
-
optional bytes message = 3;
- hasMessage() - Method in interface alluxio.grpc.TransportMessageOrBuilder
-
optional bytes message = 3;
- hasMessage() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional string message = 2;
- hasMessage() - Method in class alluxio.proto.dataserver.Protocol.Response
-
optional string message = 2;
- hasMessage() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
-
optional string message = 2;
- hasMessageType() - Method in class alluxio.grpc.SaslMessage.Builder
-
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
- hasMessageType() - Method in class alluxio.grpc.SaslMessage
-
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
- hasMessageType() - Method in interface alluxio.grpc.SaslMessageOrBuilder
-
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
- hasMetricType() - Method in class alluxio.grpc.Metric.Builder
-
required .alluxio.grpc.MetricType metricType = 5;
- hasMetricType() - Method in class alluxio.grpc.Metric
-
required .alluxio.grpc.MetricType metricType = 5;
- hasMetricType() - Method in interface alluxio.grpc.MetricOrBuilder
-
required .alluxio.grpc.MetricType metricType = 5;
- hasMetricType() - Method in class alluxio.grpc.MetricValue.Builder
-
optional .alluxio.grpc.MetricType metricType = 6;
- hasMetricType() - Method in class alluxio.grpc.MetricValue
-
optional .alluxio.grpc.MetricType metricType = 6;
- hasMetricType() - Method in interface alluxio.grpc.MetricValueOrBuilder
-
optional .alluxio.grpc.MetricType metricType = 6;
- hasMode() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- hasMode() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.PMode mode = 3;
- hasMode() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.PMode mode = 3;
- hasMode() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- hasMode() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.PMode mode = 3;
- hasMode() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.PMode mode = 3;
- hasMode() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 mode = 18;
- hasMode() - Method in class alluxio.grpc.FileInfo
-
optional int32 mode = 18;
- hasMode() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int32 mode = 18;
- hasMode() - Method in class alluxio.grpc.PAcl.Builder
-
optional int32 mode = 4;
- hasMode() - Method in class alluxio.grpc.PAcl
-
optional int32 mode = 4;
- hasMode() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional int32 mode = 4;
- hasMode() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 5;
- hasMode() - Method in class alluxio.grpc.SetAttributePOptions
-
optional .alluxio.grpc.PMode mode = 5;
- hasMode() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional .alluxio.grpc.PMode mode = 5;
- hasMode() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional int32 mode = 6;
- hasMode() - Method in class alluxio.grpc.UfsStatus
-
optional int32 mode = 6;
- hasMode() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional int32 mode = 6;
- hasMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional int32 mode = 4;
- hasMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional int32 mode = 4;
- hasMode() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional int32 mode = 4;
- hasMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int32 mode = 10;
- hasMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int32 mode = 10;
- hasMode() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int32 mode = 10;
- hasMode() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 mode = 16;
- hasMode() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int32 mode = 16;
- hasMode() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int32 mode = 16;
- hasMode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int32 mode = 11;
- hasMode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int32 mode = 11;
- hasMode() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int32 mode = 11;
- hasMostSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
-
optional int64 mostSignificantBits = 1;
- hasMostSignificantBits() - Method in class alluxio.grpc.FsOpPId
-
optional int64 mostSignificantBits = 1;
- hasMostSignificantBits() - Method in interface alluxio.grpc.FsOpPIdOrBuilder
-
optional int64 mostSignificantBits = 1;
- hasMostSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
optional int64 mostSignificantBits = 1;
- hasMostSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId
-
optional int64 mostSignificantBits = 1;
- hasMostSignificantBits() - Method in interface alluxio.proto.journal.Journal.JournalOpPIdOrBuilder
-
optional int64 mostSignificantBits = 1;
- hasMount(long) - Method in class alluxio.underfs.AbstractUfsManager
-
- hasMount(long) - Method in class alluxio.underfs.MasterUfsManager
-
- hasMount(long) - Method in interface alluxio.underfs.UfsManager
-
Checks if a mountId exists.
- hasMountId() - Method in class alluxio.grpc.Block.Builder
-
optional int64 mountId = 5;
- hasMountId() - Method in class alluxio.grpc.Block
-
optional int64 mountId = 5;
- hasMountId() - Method in interface alluxio.grpc.BlockOrBuilder
-
optional int64 mountId = 5;
- hasMountId() - Method in class alluxio.grpc.File.Builder
-
optional int64 mountId = 4;
- hasMountId() - Method in class alluxio.grpc.File
-
optional int64 mountId = 4;
- hasMountId() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 mountId = 23;
- hasMountId() - Method in class alluxio.grpc.FileInfo
-
optional int64 mountId = 23;
- hasMountId() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 mountId = 23;
- hasMountId() - Method in interface alluxio.grpc.FileOrBuilder
-
optional int64 mountId = 4;
- hasMountId() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
required int64 mountId = 1;
- hasMountId() - Method in class alluxio.grpc.GetMountIdPResponse
-
required int64 mountId = 1;
- hasMountId() - Method in interface alluxio.grpc.GetMountIdPResponseOrBuilder
-
required int64 mountId = 1;
- hasMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
the id of the ufs
- hasMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest
-
the id of the ufs
- hasMountId() - Method in interface alluxio.grpc.GetUfsInfoPRequestOrBuilder
-
the id of the ufs
- hasMountId() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 mountId = 8;
- hasMountId() - Method in class alluxio.grpc.MountPointInfo
-
optional int64 mountId = 8;
- hasMountId() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional int64 mountId = 8;
- hasMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional int64 mount_id = 5;
- hasMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional int64 mount_id = 5;
- hasMountId() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional int64 mount_id = 5;
- hasMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional int64 mountId = 5;
- hasMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
optional int64 mountId = 5;
- hasMountId() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
optional int64 mountId = 5;
- hasMountId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
optional int64 mount_id = 1;
- hasMountId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
optional int64 mount_id = 1;
- hasMountId() - Method in interface alluxio.proto.journal.File.ActiveSyncTxIdEntryOrBuilder
-
optional int64 mount_id = 1;
- hasMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional int64 mount_id = 6;
- hasMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional int64 mount_id = 6;
- hasMountId() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional int64 mount_id = 6;
- hasMountId() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
optional int64 mount_id = 2;
- hasMountId() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
-
optional int64 mount_id = 2;
- hasMountId() - Method in interface alluxio.proto.journal.File.AddSyncPointEntryOrBuilder
-
optional int64 mount_id = 2;
- hasMountId() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
optional int64 mount_id = 2;
- hasMountId() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
optional int64 mount_id = 2;
- hasMountId() - Method in interface alluxio.proto.journal.File.RemoveSyncPointEntryOrBuilder
-
optional int64 mount_id = 2;
- hasMountPoint() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool mountPoint = 20;
- hasMountPoint() - Method in class alluxio.grpc.FileInfo
-
optional bool mountPoint = 20;
- hasMountPoint() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool mountPoint = 20;
- hasMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool mount_point = 11;
- hasMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional bool mount_point = 11;
- hasMountPoint() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional bool mount_point = 11;
- hasMountPoint() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional bool mount_point = 2;
- hasMountPoint() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
-
optional bool mount_point = 2;
- hasMountPoint() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
-
optional bool mount_point = 2;
- hasMoveJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- hasMoveJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- hasMoveJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- hasMsg() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
optional string msg = 1;
- hasMsg() - Method in class alluxio.grpc.TransferLeaderMessage
-
optional string msg = 1;
- hasMsg() - Method in interface alluxio.grpc.TransferLeaderMessageOrBuilder
-
optional string msg = 1;
- hasName() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string name = 1;
- hasName() - Method in class alluxio.grpc.ConfigProperty
-
optional string name = 1;
- hasName() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
-
optional string name = 1;
- hasName() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string name = 2;
- hasName() - Method in class alluxio.grpc.FileInfo
-
optional string name = 2;
- hasName() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string name = 2;
- hasName() - Method in class alluxio.grpc.InconsistentProperty.Builder
-
optional string name = 1;
- hasName() - Method in class alluxio.grpc.InconsistentProperty
-
optional string name = 1;
- hasName() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
-
optional string name = 1;
- hasName() - Method in class alluxio.grpc.JobInfo.Builder
-
Some jobs don't have these
- hasName() - Method in class alluxio.grpc.JobInfo
-
Some jobs don't have these
- hasName() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
Some jobs don't have these
- hasName() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional string name = 2;
- hasName() - Method in class alluxio.grpc.ListAllPOptions
-
optional string name = 2;
- hasName() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
-
optional string name = 2;
- hasName() - Method in class alluxio.grpc.Metric.Builder
-
optional string name = 3;
- hasName() - Method in class alluxio.grpc.Metric
-
optional string name = 3;
- hasName() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional string name = 3;
- hasName() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional string name = 2;
- hasName() - Method in class alluxio.grpc.PolicyInfo
-
optional string name = 2;
- hasName() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
-
optional string name = 2;
- hasName() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string name = 2;
- hasName() - Method in class alluxio.grpc.table.FieldSchema
-
optional string name = 2;
- hasName() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional string name = 2;
- hasName() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string name = 1;
- hasName() - Method in class alluxio.grpc.UfsStatus
-
optional string name = 1;
- hasName() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string name = 1;
- hasName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string name = 3;
- hasName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string name = 3;
- hasName() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string name = 3;
- hasName() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string name = 3;
- hasName() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string name = 3;
- hasName() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string name = 3;
- hasName() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string name = 3;
- hasName() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string name = 3;
- hasName() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string name = 3;
- hasName() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string name = 1;
- hasName() - Method in class alluxio.proto.journal.Job.FileFilter
-
required string name = 1;
- hasName() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
-
required string name = 1;
- hasName() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional string name = 2;
- hasName() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
optional string name = 2;
- hasName() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
-
optional string name = 2;
- hasName() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
optional string name = 1;
- hasName() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
-
optional string name = 1;
- hasName() - Method in interface alluxio.proto.journal.Policy.PolicyRemoveEntryOrBuilder
-
optional string name = 1;
- hasName() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string name = 6;
- hasName() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string name = 6;
- hasName() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string name = 6;
- hasName() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional string name = 1;
- hasName() - Method in class alluxio.proto.shared.Acl.NamedAclActions
-
optional string name = 1;
- hasName() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
-
optional string name = 1;
- hasNewBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- hasNewBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- hasNewBlock() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- hasNewName() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_name = 5;
- hasNewName() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional string new_name = 5;
- hasNewName() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional string new_name = 5;
- hasNewParentId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 new_parent_id = 4;
- hasNewParentId() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional int64 new_parent_id = 4;
- hasNewParentId() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional int64 new_parent_id = 4;
- hasNewPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_path = 7;
- hasNewPath() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional string new_path = 7;
- hasNewPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional string new_path = 7;
- hasNext() - Method in class alluxio.master.file.meta.InodeTreeBufferedIterator
-
- hasNext() - Method in class alluxio.master.job.FileIterable.FileIterator
-
- hasNext() - Method in class alluxio.resource.CloseableIterator
-
- hasNext() - Method in class alluxio.underfs.ObjectUnderFileSystem.UfsStatusIterator
-
- hasNext() - Method in class alluxio.worker.block.BlockMapIterator
-
- hasNext() - Method in class alluxio.worker.block.RegisterStreamer
-
- hasNextChunk() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
-
Gets if there is more chunks to fetch WITHOUT actually fetching the next chunk.
- hasNextChunk() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunk
-
- hasNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
optional int64 next_container_id = 1;
- hasNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
-
optional int64 next_container_id = 1;
- hasNextContainerId() - Method in interface alluxio.proto.journal.Block.BlockContainerIdGeneratorEntryOrBuilder
-
optional int64 next_container_id = 1;
- hasNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
If set, do not try to cache the block locally when reading the data from the UFS.
- hasNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
If set, do not try to cache the block locally when reading the data from the UFS.
- hasNoCache() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
If set, do not try to cache the block locally when reading the data from the UFS.
- hasNodeLocalWorker() - Method in class alluxio.client.file.FileSystemContext
-
- hasNodeState() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
optional .alluxio.grpc.journal.NodeState node_state = 1;
- hasNodeState() - Method in class alluxio.grpc.GetNodeStatePResponse
-
optional .alluxio.grpc.journal.NodeState node_state = 1;
- hasNodeState() - Method in interface alluxio.grpc.GetNodeStatePResponseOrBuilder
-
optional .alluxio.grpc.journal.NodeState node_state = 1;
- hasNoRestriction() - Method in class alluxio.worker.block.BlockStoreLocation
-
- hasNumActiveTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 numActiveTasks = 6;
- hasNumActiveTasks() - Method in class alluxio.grpc.JobWorkerHealth
-
optional int32 numActiveTasks = 6;
- hasNumActiveTasks() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional int32 numActiveTasks = 6;
- hasNumDistincts() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional int64 num_distincts = 4;
- hasNumDistincts() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional int64 num_distincts = 4;
- hasNumFalses() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_falses = 2;
- hasNumFalses() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
optional int64 num_falses = 2;
- hasNumFalses() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
-
optional int64 num_falses = 2;
- hasNumNulls() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.DateColumnStatsData
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.DecimalColumnStatsData
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.DoubleColumnStatsData
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.LongColumnStatsData
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional int64 num_nulls = 3;
- hasNumNulls() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional int64 num_nulls = 3;
- hasNumTrues() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_trues = 1;
- hasNumTrues() - Method in class alluxio.grpc.table.BooleanColumnStatsData
-
optional int64 num_trues = 1;
- hasNumTrues() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
-
optional int64 num_trues = 1;
- hasOffset() - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional int64 offset = 2;
- hasOffset() - Method in class alluxio.grpc.FileBlockInfo
-
optional int64 offset = 2;
- hasOffset() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
-
optional int64 offset = 2;
- hasOffset() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 offset = 2;
- hasOffset() - Method in class alluxio.grpc.ReadRequest
-
optional int64 offset = 2;
- hasOffset() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
optional int64 offset = 2;
- hasOffset() - Method in class alluxio.grpc.SnapshotData.Builder
-
Deprecated.
- hasOffset() - Method in class alluxio.grpc.SnapshotData
-
Deprecated.
- hasOffset() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
Deprecated.
- hasOffset() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional int64 offset = 3;
- hasOffset() - Method in class alluxio.grpc.WriteRequestCommand
-
optional int64 offset = 3;
- hasOffset() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional int64 offset = 3;
- hasOffset() - Method in class alluxio.grpc.WriteResponse.Builder
-
optional int64 offset = 1;
- hasOffset() - Method in class alluxio.grpc.WriteResponse
-
optional int64 offset = 1;
- hasOffset() - Method in interface alluxio.grpc.WriteResponseOrBuilder
-
optional int64 offset = 1;
- hasOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 offset = 2;
- hasOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
optional int64 offset = 2;
- hasOffset() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
optional int64 offset = 2;
- hasOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional int64 offset = 3;
- hasOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
optional int64 offset = 3;
- hasOffset() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
optional int64 offset = 3;
- hasOffsetCount() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Only start listing items after this many items have been processed.
- hasOffsetCount() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Only start listing items after this many items have been processed.
- hasOffsetCount() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Only start listing items after this many items have been processed.
- hasOffsetId() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Start listing after the given FileId, the FileId can be calculated from the
result of a previous listing's FileInfo or URIStatus results using the
getFileId method.
- hasOffsetId() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Start listing after the given FileId, the FileId can be calculated from the
result of a previous listing's FileInfo or URIStatus results using the
getFileId method.
- hasOffsetId() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Start listing after the given FileId, the FileId can be calculated from the
result of a previous listing's FileInfo or URIStatus results using the
getFileId method.
- hasOffsetInFile() - Method in class alluxio.grpc.Block.Builder
-
The offset of the block in within ufs the file.
- hasOffsetInFile() - Method in class alluxio.grpc.Block
-
The offset of the block in within ufs the file.
- hasOffsetInFile() - Method in interface alluxio.grpc.BlockOrBuilder
-
The offset of the block in within ufs the file.
- hasOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The offset of the block in within the file.
- hasOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
The offset of the block in within the file.
- hasOffsetInFile() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
The offset of the block in within the file.
- hasOffsetReceived() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- hasOffsetReceived() - Method in class alluxio.grpc.DownloadSnapshotPRequest
-
Deprecated.
- hasOffsetReceived() - Method in interface alluxio.grpc.DownloadSnapshotPRequestOrBuilder
-
Deprecated.
- hasOffsetReceived() - Method in class alluxio.grpc.ReadRequest.Builder
-
Read receipt
- hasOffsetReceived() - Method in class alluxio.grpc.ReadRequest
-
Read receipt
- hasOffsetReceived() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
Read receipt
- hasOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- hasOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse
-
Deprecated.
- hasOffsetReceived() - Method in interface alluxio.grpc.UploadSnapshotPResponseOrBuilder
-
Deprecated.
- hasOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
If set, only reserve space for the block.
- hasOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
If set, only reserve space for the block.
- hasOnlyReserveSpace() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
-
If set, only reserve space for the block.
- hasOpenUfsBlockOptions() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- hasOpenUfsBlockOptions() - Method in class alluxio.grpc.AsyncCacheRequest
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- hasOpenUfsBlockOptions() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- hasOpenUfsBlockOptions() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- hasOpenUfsBlockOptions() - Method in class alluxio.grpc.CacheRequest
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- hasOpenUfsBlockOptions() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- hasOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest.Builder
-
This is only set for UFS block read.
- hasOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest
-
This is only set for UFS block read.
- hasOpenUfsBlockOptions() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
This is only set for UFS block read.
- hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- hasOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
This is only set for UFS block read.
- hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
This is only set for UFS block read.
- hasOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
This is only set for UFS block read.
- hasOperation() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string operation = 1;
- hasOperation() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string operation = 1;
- hasOperation() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string operation = 1;
- hasOperationId() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- hasOperationId() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- hasOperationId() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- hasOperationId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- hasOperationId() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- hasOperationId() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- hasOperationType() - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
optional .alluxio.grpc.job.OperationType operationType = 3;
- hasOperationType() - Method in class alluxio.grpc.CmdStatusBlock
-
optional .alluxio.grpc.job.OperationType operationType = 3;
- hasOperationType() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
-
optional .alluxio.grpc.job.OperationType operationType = 3;
- hasOperationType() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.OperationType operationType = 2;
- hasOperationType() - Method in class alluxio.grpc.CmdSummary
-
optional .alluxio.grpc.job.OperationType operationType = 2;
- hasOperationType() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional .alluxio.grpc.job.OperationType operationType = 2;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 op_time_ms = 4;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
optional int64 op_time_ms = 4;
- hasOpTimeMs() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
optional int64 op_time_ms = 4;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional int64 op_time_ms = 3;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
optional int64 op_time_ms = 3;
- hasOpTimeMs() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
optional int64 op_time_ms = 3;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 op_time_ms = 3;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry
-
optional int64 op_time_ms = 3;
- hasOpTimeMs() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
-
optional int64 op_time_ms = 3;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 op_time_ms = 3;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional int64 op_time_ms = 3;
- hasOpTimeMs() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional int64 op_time_ms = 3;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional int64 op_time_ms = 2;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.SetAclEntry
-
optional int64 op_time_ms = 2;
- hasOpTimeMs() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
optional int64 op_time_ms = 2;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 op_time_ms = 2;
- hasOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int64 op_time_ms = 2;
- hasOpTimeMs() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int64 op_time_ms = 2;
- hasOptions() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.AddPolicyPRequest
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.BackupPRequest
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- hasOptions() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- hasOptions() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- hasOptions() - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CancelPRequest
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.CancelPRequestOrBuilder
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CheckAccessPRequest
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- hasOptions() - Method in class alluxio.grpc.CommitBlockPRequest
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- hasOptions() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- hasOptions() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CompleteFilePRequest
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.CreateFilePRequest
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.DeletePRequest.Builder
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.DeletePRequest
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.ExistsPRequest
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- hasOptions() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.FreePRequest.Builder
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.FreePRequest
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.FreePRequestOrBuilder
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- hasOptions() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- hasOptions() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- hasOptions() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.GetAllMasterStatusPRequestOrBuilder
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.GetAllWorkerHealthPRequestOrBuilder
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetBlockInfoPRequest
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetBlockInfoPRequestOrBuilder
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetCmdStatusDetailedRequestOrBuilder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetCmdStatusRequest
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetCmdStatusRequestOrBuilder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetFileInfoPRequest
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetFileInfoPRequestOrBuilder
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetJobMasterIdPRequest
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetJobProgressPRequest
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.GetJobServiceSummaryPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetJobStatusDetailedPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetJobStatusPRequest
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetJobStatusPRequestOrBuilder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetMasterIdPRequest
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.GetPinnedFileIdsPRequestOrBuilder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.GetQuorumInfoPRequestOrBuilder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- hasOptions() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- hasOptions() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- hasOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.GetStateLockHoldersPRequestOrBuilder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetStatusPRequest
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetUfsInfoPRequestOrBuilder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- hasOptions() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.JobMasterHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.ListAllPRequest.Builder
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.ListAllPRequest
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.ListAllPRequestOrBuilder
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.ListPolicyPRequest
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.ListPolicyPRequestOrBuilder
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.ListProxyStatusPRequest
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.ListProxyStatusPRequestOrBuilder
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.ListStatusPRequest
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.LoadFileRequest
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.LoadRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.LoadRequest
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.LoadRequestOrBuilder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.MasterHeartbeatPRequest
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.MasterHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.MetricsHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.MountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.MountPRequest
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- hasOptions() - Method in interface alluxio.grpc.MountPRequestOrBuilder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- hasOptions() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- hasOptions() - Method in class alluxio.grpc.PolicyInfo
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- hasOptions() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- hasOptions() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.ProxyHeartbeatPRequestOrBuilder
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.RegisterJobMasterPRequest
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.RegisterJobMasterPRequestOrBuilder
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.RegisterMasterPRequest
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.RegisterMasterPRequestOrBuilder
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- hasOptions() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- hasOptions() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- hasOptions() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- hasOptions() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.RemovePolicyPRequest
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.RenamePRequest.Builder
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.RenamePRequest
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- hasOptions() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.ResetPrioritiesPRequest
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.ResetPrioritiesPRequestOrBuilder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.RunPRequest.Builder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.RunPRequest
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.RunPRequestOrBuilder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the method options
- hasOptions() - Method in class alluxio.grpc.SetAclPRequest
-
the method options
- hasOptions() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the method options
- hasOptions() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.SetAttributePRequest
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- hasOptions() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.SubmitRequest
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.SubmitRequestOrBuilder
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- hasOptions() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- hasOptions() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.UnmountPRequest
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.UpdateMountPRequest
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- hasOptions() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- hasOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- hasOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- hasOptions() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- hasOptions() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- hasOptions() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- hasOptions() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- hasOrder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
- hasOrder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
-
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
- hasOrder() - Method in interface alluxio.grpc.table.layout.hive.SortingColumnOrBuilder
-
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
- hasOtherActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- hasOtherActions() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- hasOtherActions() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- hasOtherBits() - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits otherBits = 3;
- hasOtherBits() - Method in class alluxio.grpc.PMode
-
required .alluxio.grpc.Bits otherBits = 3;
- hasOtherBits() - Method in interface alluxio.grpc.PModeOrBuilder
-
required .alluxio.grpc.Bits otherBits = 3;
- hasOutputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string output_format = 3;
- hasOutputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
optional string output_format = 3;
- hasOutputFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
optional string output_format = 3;
- hasOverwrite() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool overwrite = 4;
- hasOverwrite() - Method in class alluxio.grpc.CopyJobPOptions
-
optional bool overwrite = 4;
- hasOverwrite() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional bool overwrite = 4;
- hasOverwrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool overwrite = 13;
- hasOverwrite() - Method in class alluxio.grpc.CreateFilePOptions
-
optional bool overwrite = 13;
- hasOverwrite() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional bool overwrite = 13;
- hasOverwrite() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool overwrite = 4;
- hasOverwrite() - Method in class alluxio.grpc.MoveJobPOptions
-
optional bool overwrite = 4;
- hasOverwrite() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional bool overwrite = 4;
- hasOverwrite() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
optional bool overwrite = 1;
- hasOverwrite() - Method in class alluxio.grpc.S3SyntaxOptions
-
optional bool overwrite = 1;
- hasOverwrite() - Method in interface alluxio.grpc.S3SyntaxOptionsOrBuilder
-
optional bool overwrite = 1;
- hasOverwrite() - Method in class alluxio.grpc.WriteOptions.Builder
-
optional bool overwrite = 1;
- hasOverwrite() - Method in class alluxio.grpc.WriteOptions
-
optional bool overwrite = 1;
- hasOverwrite() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
-
optional bool overwrite = 1;
- hasOverwrite() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional bool overwrite = 10;
- hasOverwrite() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional bool overwrite = 10;
- hasOverwrite() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional bool overwrite = 10;
- hasOverwrite() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional bool overwrite = 10;
- hasOverwrite() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional bool overwrite = 10;
- hasOverwrite() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional bool overwrite = 10;
- hasOverwriteAccessTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool overwrite_access_time = 19;
- hasOverwriteAccessTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional bool overwrite_access_time = 19;
- hasOverwriteAccessTime() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional bool overwrite_access_time = 19;
- hasOverwriteModificationTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool overwrite_modification_time = 8;
- hasOverwriteModificationTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional bool overwrite_modification_time = 8;
- hasOverwriteModificationTime() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional bool overwrite_modification_time = 8;
- hasOwner() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string owner = 16;
- hasOwner() - Method in class alluxio.grpc.FileInfo
-
optional string owner = 16;
- hasOwner() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string owner = 16;
- hasOwner() - Method in class alluxio.grpc.PAcl.Builder
-
optional string owner = 1;
- hasOwner() - Method in class alluxio.grpc.PAcl
-
optional string owner = 1;
- hasOwner() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional string owner = 1;
- hasOwner() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string owner = 3;
- hasOwner() - Method in class alluxio.grpc.SetAttributePOptions
-
optional string owner = 3;
- hasOwner() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional string owner = 3;
- hasOwner() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string owner = 4;
- hasOwner() - Method in class alluxio.grpc.table.TableInfo
-
optional string owner = 4;
- hasOwner() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional string owner = 4;
- hasOwner() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string owner = 4;
- hasOwner() - Method in class alluxio.grpc.UfsStatus
-
optional string owner = 4;
- hasOwner() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string owner = 4;
- hasOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string owner = 2;
- hasOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional string owner = 2;
- hasOwner() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional string owner = 2;
- hasOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string owner = 8;
- hasOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string owner = 8;
- hasOwner() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string owner = 8;
- hasOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string owner = 14;
- hasOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string owner = 14;
- hasOwner() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string owner = 14;
- hasOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string owner = 6;
- hasOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string owner = 6;
- hasOwner() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string owner = 6;
- hasOwner() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string owner = 9;
- hasOwner() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string owner = 9;
- hasOwner() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string owner = 9;
- hasOwnerBits() - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits ownerBits = 1;
- hasOwnerBits() - Method in class alluxio.grpc.PMode
-
required .alluxio.grpc.Bits ownerBits = 1;
- hasOwnerBits() - Method in interface alluxio.grpc.PModeOrBuilder
-
required .alluxio.grpc.Bits ownerBits = 1;
- hasOwnerName() - Method in class alluxio.grpc.table.Database.Builder
-
optional string owner_name = 5;
- hasOwnerName() - Method in class alluxio.grpc.table.Database
-
optional string owner_name = 5;
- hasOwnerName() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string owner_name = 5;
- hasOwnerType() - Method in class alluxio.grpc.table.Database.Builder
-
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
- hasOwnerType() - Method in class alluxio.grpc.table.Database
-
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
- hasOwnerType() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
- hasOwningGroup() - Method in class alluxio.grpc.PAcl.Builder
-
optional string owningGroup = 2;
- hasOwningGroup() - Method in class alluxio.grpc.PAcl
-
optional string owningGroup = 2;
- hasOwningGroup() - Method in interface alluxio.grpc.PAclOrBuilder
-
optional string owningGroup = 2;
- hasOwningGroup() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningGroup = 2;
- hasOwningGroup() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional string owningGroup = 2;
- hasOwningGroup() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional string owningGroup = 2;
- hasOwningUser() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningUser = 1;
- hasOwningUser() - Method in class alluxio.proto.shared.Acl.AccessControlList
-
optional string owningUser = 1;
- hasOwningUser() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
-
optional string owningUser = 1;
- hasPage(PageId) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
-
- hasPage(PageId) - Method in interface alluxio.client.file.cache.PageMetaStore
-
- hasPageSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional int64 pageSize = 1;
- hasPageSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
optional int64 pageSize = 1;
- hasPageSize() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
-
optional int64 pageSize = 1;
- hasParentId() - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 parentId = 10;
- hasParentId() - Method in class alluxio.grpc.JobInfo
-
optional int64 parentId = 10;
- hasParentId() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional int64 parentId = 10;
- hasParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 parent_id = 2;
- hasParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 parent_id = 2;
- hasParentId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 parent_id = 2;
- hasParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 parent_id = 2;
- hasParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 parent_id = 2;
- hasParentId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 parent_id = 2;
- hasParentId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 parent_id = 2;
- hasParentId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 parent_id = 2;
- hasParentId() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 parent_id = 2;
- hasParentId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 parent_id = 7;
- hasParentId() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 parent_id = 7;
- hasParentId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 parent_id = 7;
- hasPartialListing() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool partialListing = 3;
- hasPartialListing() - Method in class alluxio.grpc.CopyJobPOptions
-
optional bool partialListing = 3;
- hasPartialListing() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional bool partialListing = 3;
- hasPartialListing() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool partialListing = 3;
- hasPartialListing() - Method in class alluxio.grpc.LoadJobPOptions
-
optional bool partialListing = 3;
- hasPartialListing() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
-
optional bool partialListing = 3;
- hasPartialListing() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool partialListing = 3;
- hasPartialListing() - Method in class alluxio.grpc.MoveJobPOptions
-
optional bool partialListing = 3;
- hasPartialListing() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional bool partialListing = 3;
- hasPartialListing() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required bool partialListing = 7;
- hasPartialListing() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required bool partialListing = 7;
- hasPartialListing() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required bool partialListing = 7;
- hasPartialListing() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required bool partialListing = 6;
- hasPartialListing() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required bool partialListing = 6;
- hasPartialListing() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required bool partialListing = 6;
- hasPartialListing() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required bool partialListing = 7;
- hasPartialListing() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required bool partialListing = 7;
- hasPartialListing() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required bool partialListing = 7;
- hasPartitionName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
partition name in the form of "key=value"
- hasPartitionName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
partition name in the form of "key=value"
- hasPartitionName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
partition name in the form of "key=value"
- hasPartitionSpec() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- hasPartitionSpec() - Method in class alluxio.grpc.table.Partition
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- hasPartitionSpec() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- hasPath() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional string path = 1;
- hasPath() - Method in class alluxio.grpc.CheckAccessPRequest
-
optional string path = 1;
- hasPath() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
-
optional string path = 1;
- hasPath() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
the root of the subtree to check
- hasPath() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
the root of the subtree to check
- hasPath() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
-
the root of the subtree to check
- hasPath() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
the path of the file
- hasPath() - Method in class alluxio.grpc.CompleteFilePRequest
-
the path of the file
- hasPath() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
-
the path of the file
- hasPath() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
the path of the directory
- hasPath() - Method in class alluxio.grpc.CreateDirectoryPRequest
-
the path of the directory
- hasPath() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
-
the path of the directory
- hasPath() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
the path of the file
- hasPath() - Method in class alluxio.grpc.CreateFilePRequest
-
the path of the file
- hasPath() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
-
the path of the file
- hasPath() - Method in class alluxio.grpc.DeletePRequest.Builder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.DeletePRequest
-
the path of the file or directory
- hasPath() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional string path = 1;
- hasPath() - Method in class alluxio.grpc.ExistsPRequest
-
optional string path = 1;
- hasPath() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
-
optional string path = 1;
- hasPath() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string path = 3;
- hasPath() - Method in class alluxio.grpc.FileInfo
-
optional string path = 3;
- hasPath() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string path = 3;
- hasPath() - Method in class alluxio.grpc.FreePRequest.Builder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.FreePRequest
-
the path of the file or directory
- hasPath() - Method in interface alluxio.grpc.FreePRequestOrBuilder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
optional string path = 1;
- hasPath() - Method in class alluxio.grpc.GetFilePathPResponse
-
optional string path = 1;
- hasPath() - Method in interface alluxio.grpc.GetFilePathPResponseOrBuilder
-
optional string path = 1;
- hasPath() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
the path of the file
- hasPath() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
-
the path of the file
- hasPath() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
-
the path of the file
- hasPath() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.GetStatusPRequest
-
the path of the file or directory
- hasPath() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.JobDescription.Builder
-
optional string path = 2;
- hasPath() - Method in class alluxio.grpc.JobDescription
-
optional string path = 2;
- hasPath() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
-
optional string path = 2;
- hasPath() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.ListStatusPartialPRequest
-
the path of the file or directory
- hasPath() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.ListStatusPRequest
-
the path of the file or directory
- hasPath() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
required string path = 1;
- hasPath() - Method in class alluxio.grpc.NeedsSyncRequest
-
required string path = 1;
- hasPath() - Method in interface alluxio.grpc.NeedsSyncRequestOrBuilder
-
required string path = 1;
- hasPath() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional string path = 1;
- hasPath() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
-
optional string path = 1;
- hasPath() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
-
optional string path = 1;
- hasPath() - Method in class alluxio.grpc.RenamePRequest.Builder
-
the source path of the file or directory
- hasPath() - Method in class alluxio.grpc.RenamePRequest
-
the source path of the file or directory
- hasPath() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
-
the source path of the file or directory
- hasPath() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
the path of the file
- hasPath() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
-
the path of the file
- hasPath() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
-
the path of the file
- hasPath() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.SetAclPRequest
-
the path of the file or directory
- hasPath() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
-
the path of the file or directory
- hasPath() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
the path of the file
- hasPath() - Method in class alluxio.grpc.SetAttributePRequest
-
the path of the file
- hasPath() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
-
the path of the file
- hasPath() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional string path = 1;
- hasPath() - Method in class alluxio.grpc.SetPathConfigurationPRequest
-
optional string path = 1;
- hasPath() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
-
optional string path = 1;
- hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
optional string path = 1;
- hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
-
optional string path = 1;
- hasPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateResponseOrBuilder
-
optional string path = 1;
- hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
optional string path = 1;
- hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
-
optional string path = 1;
- hasPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenResponseOrBuilder
-
optional string path = 1;
- hasPath() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional string path = 5;
- hasPath() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
optional string path = 5;
- hasPath() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
optional string path = 5;
- hasPath() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string path = 17;
- hasPath() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string path = 17;
- hasPath() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string path = 17;
- hasPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string path = 25;
- hasPath() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string path = 25;
- hasPath() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string path = 25;
- hasPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string path = 6;
- hasPath() - Method in class alluxio.proto.journal.File.RenameEntry
-
optional string path = 6;
- hasPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
-
optional string path = 6;
- hasPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string path = 12;
- hasPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional string path = 12;
- hasPath() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional string path = 12;
- hasPath() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
optional string path = 1;
- hasPath() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
optional string path = 1;
- hasPath() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
-
optional string path = 1;
- hasPath() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
optional string path = 1;
- hasPath() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
-
optional string path = 1;
- hasPath() - Method in interface alluxio.proto.journal.Meta.RemovePathPropertiesEntryOrBuilder
-
optional string path = 1;
- hasPathConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string pathConfigHash = 2;
- hasPathConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse
-
optional string pathConfigHash = 2;
- hasPathConfigHash() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
-
optional string pathConfigHash = 2;
- hasPathConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string pathConfigHash = 4;
- hasPathConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse
-
optional string pathConfigHash = 4;
- hasPathConfigHash() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
optional string pathConfigHash = 4;
- hasPathConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional int64 pathConfigLastUpdateTime = 6;
- hasPathConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse
-
optional int64 pathConfigLastUpdateTime = 6;
- hasPathConfigLastUpdateTime() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
-
optional int64 pathConfigLastUpdateTime = 6;
- hasPathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- hasPathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- hasPathProperties() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- hasPattern() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
optional string pattern = 2;
- hasPattern() - Method in class alluxio.proto.journal.Job.FileFilter
-
optional string pattern = 2;
- hasPattern() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
-
optional string pattern = 2;
- hasPayload() - Method in class alluxio.network.protocol.RPCMessage
-
Returns true if the message has a payload.
- hasPayload() - Method in class alluxio.network.protocol.RPCProtoMessage
-
- hasPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 permission = 8;
- hasPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int32 permission = 8;
- hasPermission() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int32 permission = 8;
- hasPersist() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional bool persist = 2;
- hasPersist() - Method in class alluxio.grpc.RenamePOptions
-
optional bool persist = 2;
- hasPersist() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
-
optional bool persist = 2;
- hasPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- hasPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- hasPersistDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- hasPersisted() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool persisted = 12;
- hasPersisted() - Method in class alluxio.grpc.FileInfo
-
optional bool persisted = 12;
- hasPersisted() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool persisted = 12;
- hasPersisted() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool persisted = 2;
- hasPersisted() - Method in class alluxio.grpc.SetAttributePOptions
-
optional bool persisted = 2;
- hasPersisted() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional bool persisted = 2;
- hasPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional bool persisted = 5;
- hasPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional bool persisted = 5;
- hasPersisted() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional bool persisted = 5;
- hasPersistenceState() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string persistenceState = 19;
- hasPersistenceState() - Method in class alluxio.grpc.FileInfo
-
optional string persistenceState = 19;
- hasPersistenceState() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string persistenceState = 19;
- hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string persistence_state = 4;
- hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional string persistence_state = 4;
- hasPersistenceState() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional string persistence_state = 4;
- hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string persistence_state = 4;
- hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string persistence_state = 4;
- hasPersistenceState() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string persistence_state = 4;
- hasPersistenceState() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string persistence_state = 4;
- hasPersistenceState() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string persistence_state = 4;
- hasPersistenceState() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string persistence_state = 4;
- hasPersistenceState() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persistence_state = 8;
- hasPersistenceState() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string persistence_state = 8;
- hasPersistenceState() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string persistence_state = 8;
- hasPersistenceWaitTime() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int64 persistenceWaitTime = 10;
- hasPersistenceWaitTime() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int64 persistenceWaitTime = 10;
- hasPersistenceWaitTime() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int64 persistenceWaitTime = 10;
- hasPersistenceWaitTime() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional int64 persistenceWaitTime = 2;
- hasPersistenceWaitTime() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
optional int64 persistenceWaitTime = 2;
- hasPersistenceWaitTime() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
-
optional int64 persistenceWaitTime = 2;
- hasPersistJobId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 persist_job_id = 22;
- hasPersistJobId() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 persist_job_id = 22;
- hasPersistJobId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 persist_job_id = 22;
- hasPersistJobId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 persistJobId = 11;
- hasPersistJobId() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int64 persistJobId = 11;
- hasPersistJobId() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int64 persistJobId = 11;
- hasPersistJobId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 persist_job_id = 10;
- hasPersistJobId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int64 persist_job_id = 10;
- hasPersistJobId() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int64 persist_job_id = 10;
- hasPersistJobId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
Used for recovering in-progress file persist jobs on master start.
- hasPersistJobId() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
Used for recovering in-progress file persist jobs on master start.
- hasPersistJobId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
Used for recovering in-progress file persist jobs on master start.
- hasPersistJobTempUfsPath() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persist_job_temp_ufs_path = 24;
- hasPersistJobTempUfsPath() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string persist_job_temp_ufs_path = 24;
- hasPersistJobTempUfsPath() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string persist_job_temp_ufs_path = 24;
- hasPersistOptions() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- hasPersistOptions() - Method in class alluxio.grpc.FileSystemCommandOptions
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- hasPersistOptions() - Method in interface alluxio.grpc.FileSystemCommandOptionsOrBuilder
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- hasPinned() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool pinned = 10;
- hasPinned() - Method in class alluxio.grpc.FileInfo
-
optional bool pinned = 10;
- hasPinned() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool pinned = 10;
- hasPinned() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool pinned = 1;
- hasPinned() - Method in class alluxio.grpc.SetAttributePOptions
-
optional bool pinned = 1;
- hasPinned() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional bool pinned = 1;
- hasPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool pinned = 5;
- hasPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional bool pinned = 5;
- hasPinned() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional bool pinned = 5;
- hasPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool pinned = 5;
- hasPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional bool pinned = 5;
- hasPinned() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional bool pinned = 5;
- hasPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional bool pinned = 3;
- hasPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional bool pinned = 3;
- hasPinned() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional bool pinned = 3;
- hasPinned() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool pinned = 5;
- hasPinned() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional bool pinned = 5;
- hasPinned() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional bool pinned = 5;
- hasPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional bool pin_on_create = 9;
- hasPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand
-
optional bool pin_on_create = 9;
- hasPinOnCreate() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional bool pin_on_create = 9;
- hasPolicy() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- hasPolicy() - Method in class alluxio.grpc.AddPolicyPResponse
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- hasPolicy() - Method in interface alluxio.grpc.AddPolicyPResponseOrBuilder
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- hasPolicyDefinition() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- hasPolicyDefinition() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- hasPolicyDefinition() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- hasPolicyName() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional string policyName = 1;
- hasPolicyName() - Method in class alluxio.grpc.AddPolicyPRequest
-
optional string policyName = 1;
- hasPolicyName() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
-
optional string policyName = 1;
- hasPolicyName() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string policyName = 1;
- hasPolicyName() - Method in class alluxio.grpc.GetActionInfoRequest
-
optional string policyName = 1;
- hasPolicyName() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
-
optional string policyName = 1;
- hasPolicyName() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional string policyName = 1;
- hasPolicyName() - Method in class alluxio.grpc.GetPolicyStatusPRequest
-
optional string policyName = 1;
- hasPolicyName() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
-
optional string policyName = 1;
- hasPolicyName() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional string policyName = 1;
- hasPolicyName() - Method in class alluxio.grpc.RemovePolicyPRequest
-
optional string policyName = 1;
- hasPolicyName() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
-
optional string policyName = 1;
- hasPolicyName() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
optional string policyName = 1;
- hasPolicyName() - Method in class alluxio.grpc.TriggerPolicyRequest
-
optional string policyName = 1;
- hasPolicyName() - Method in interface alluxio.grpc.TriggerPolicyRequestOrBuilder
-
optional string policyName = 1;
- hasPolicyRemove() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- hasPolicyRemove() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- hasPolicyRemove() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- hasPositionShort() - Method in class alluxio.grpc.ReadRequest.Builder
-
Is position read to a small buffer
- hasPositionShort() - Method in class alluxio.grpc.ReadRequest
-
Is position read to a small buffer
- hasPositionShort() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
Is position read to a small buffer
- hasPositionShort() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
is position short or not, used for HDFS performance optimization.
- hasPositionShort() - Method in class alluxio.grpc.UfsReadOptions
-
is position short or not, used for HDFS performance optimization.
- hasPositionShort() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
-
is position short or not, used for HDFS performance optimization.
- hasPrefix() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Only match files with a given prefix.
- hasPrefix() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Only match files with a given prefix.
- hasPrefix() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Only match files with a given prefix.
- hasPrefix(String, String) - Static method in class alluxio.util.io.PathUtils
-
Checks whether the given path contains the given prefix.
- hasPreviousVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 previous_version = 9;
- hasPreviousVersion() - Method in class alluxio.grpc.table.TableInfo
-
optional int64 previous_version = 9;
- hasPreviousVersion() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional int64 previous_version = 9;
- hasPriority() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional int32 priority = 4;
- hasPriority() - Method in class alluxio.grpc.QuorumServerInfo
-
optional int32 priority = 4;
- hasPriority() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
-
optional int32 priority = 4;
- hasProcessLocalWorker() - Method in class alluxio.client.file.FileSystemContext
-
- hasProgressPercentage() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional float progressPercentage = 9;
- hasProgressPercentage() - Method in class alluxio.grpc.CmdSummary
-
optional float progressPercentage = 9;
- hasProgressPercentage() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional float progressPercentage = 9;
- hasProgressReport() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
optional string progressReport = 1;
- hasProgressReport() - Method in class alluxio.grpc.GetJobProgressPResponse
-
optional string progressReport = 1;
- hasProgressReport() - Method in interface alluxio.grpc.GetJobProgressPResponseOrBuilder
-
optional string progressReport = 1;
- hasPromote() - Method in class alluxio.grpc.ReadRequest.Builder
-
Whether the block should be promoted before reading
- hasPromote() - Method in class alluxio.grpc.ReadRequest
-
Whether the block should be promoted before reading
- hasPromote() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
Whether the block should be promoted before reading
- hasPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
optional bool promote = 2;
- hasPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
-
optional bool promote = 2;
- hasPromote() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
-
optional bool promote = 2;
- hasPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
Whether the block should be promoted before reading
- hasPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
-
Whether the block should be promoted before reading
- hasPromote() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
-
Whether the block should be promoted before reading
- hasProperties() - Method in class alluxio.grpc.UfsInfo.Builder
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- hasProperties() - Method in class alluxio.grpc.UfsInfo
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- hasProperties() - Method in interface alluxio.grpc.UfsInfoOrBuilder
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- hasProxyAddress() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- hasProxyAddress() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- hasProxyAddress() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- hasProxyFor(InetSocketAddress) - Method in class alluxio.master.transport.GrpcMessagingProxy
-
- hasQueuedSubmissions() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns true
if there are any tasks submitted to this pool that have not yet begun
executing.
- hasRaftJournal() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional bool raftJournal = 12;
- hasRaftJournal() - Method in class alluxio.grpc.MasterInfo
-
optional bool raftJournal = 12;
- hasRaftJournal() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional bool raftJournal = 12;
- hasRange() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.RangeSet range = 1;
- hasRange() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.RangeSet range = 1;
- hasRange() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.RangeSet range = 1;
- hasRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool rawValue = 1;
- hasRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions
-
optional bool rawValue = 1;
- hasRawValue() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
-
optional bool rawValue = 1;
- hasReadOnly() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional bool readOnly = 5;
- hasReadOnly() - Method in class alluxio.grpc.MountPointInfo
-
optional bool readOnly = 5;
- hasReadOnly() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional bool readOnly = 5;
- hasReadOnly() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional bool readOnly = 1;
- hasReadOnly() - Method in class alluxio.grpc.MountPOptions
-
optional bool readOnly = 1;
- hasReadOnly() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
optional bool readOnly = 1;
- hasReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional bool readOnly = 3;
- hasReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional bool readOnly = 3;
- hasReadOnly() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional bool readOnly = 3;
- hasReadType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.ReadPType readType = 1;
- hasReadType() - Method in class alluxio.grpc.OpenFilePOptions
-
optional .alluxio.grpc.file.ReadPType readType = 1;
- hasReadType() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.ReadPType readType = 1;
- hasRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool recursive = 1;
- hasRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional bool recursive = 1;
- hasRecursive() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional bool recursive = 1;
- hasRecursive() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool recursive = 2;
- hasRecursive() - Method in class alluxio.grpc.CreateFilePOptions
-
optional bool recursive = 2;
- hasRecursive() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional bool recursive = 2;
- hasRecursive() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool recursive = 1;
- hasRecursive() - Method in class alluxio.grpc.DeletePOptions
-
optional bool recursive = 1;
- hasRecursive() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional bool recursive = 1;
- hasRecursive() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional bool recursive = 1;
- hasRecursive() - Method in class alluxio.grpc.FreePOptions
-
optional bool recursive = 1;
- hasRecursive() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
-
optional bool recursive = 1;
- hasRecursive() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional bool recursive = 4;
- hasRecursive() - Method in class alluxio.grpc.ListStatusPOptions
-
optional bool recursive = 4;
- hasRecursive() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
optional bool recursive = 4;
- hasRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
whether to load metadata recursively
- hasRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions
-
whether to load metadata recursively
- hasRecursive() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
whether to load metadata recursively
- hasRecursive() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional bool recursive = 2;
- hasRecursive() - Method in class alluxio.grpc.SetAclPOptions
-
optional bool recursive = 2;
- hasRecursive() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
-
optional bool recursive = 2;
- hasRecursive() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool recursive = 6;
- hasRecursive() - Method in class alluxio.grpc.SetAttributePOptions
-
optional bool recursive = 6;
- hasRecursive() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional bool recursive = 6;
- hasRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
Deprecated, we now write one journal entry per inode removed
- hasRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry
-
Deprecated, we now write one journal entry per inode removed
- hasRecursive() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
-
Deprecated, we now write one journal entry per inode removed
- hasRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional bool recursive = 5;
- hasRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry
-
optional bool recursive = 5;
- hasRecursive() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
-
optional bool recursive = 5;
- hasRegisterCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- hasRegisterCommand() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- hasRegisterCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- hasRegisterLease(long) - Method in interface alluxio.master.block.BlockMaster
-
- hasRegisterLease(long) - Method in class alluxio.master.block.DefaultBlockMaster
-
- hasRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- hasRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- hasRemovePathProperties() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- hasRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- hasRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- hasRemoveSyncPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- hasRename() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- hasRename() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- hasRename() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- hasReplicationDurable() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationDurable = 6;
- hasReplicationDurable() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int32 replicationDurable = 6;
- hasReplicationDurable() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int32 replicationDurable = 6;
- hasReplicationDurable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_durable = 24;
- hasReplicationDurable() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int32 replication_durable = 24;
- hasReplicationDurable() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int32 replication_durable = 24;
- hasReplicationDurable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_durable = 20;
- hasReplicationDurable() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int32 replication_durable = 20;
- hasReplicationDurable() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int32 replication_durable = 20;
- hasReplicationMax() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationMax = 4;
- hasReplicationMax() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int32 replicationMax = 4;
- hasReplicationMax() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int32 replicationMax = 4;
- hasReplicationMax() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 replicationMax = 29;
- hasReplicationMax() - Method in class alluxio.grpc.FileInfo
-
optional int32 replicationMax = 29;
- hasReplicationMax() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int32 replicationMax = 29;
- hasReplicationMax() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional int32 replicationMax = 7;
- hasReplicationMax() - Method in class alluxio.grpc.SetAttributePOptions
-
optional int32 replicationMax = 7;
- hasReplicationMax() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional int32 replicationMax = 7;
- hasReplicationMax() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_max = 20;
- hasReplicationMax() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int32 replication_max = 20;
- hasReplicationMax() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int32 replication_max = 20;
- hasReplicationMax() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 replication_max = 13;
- hasReplicationMax() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int32 replication_max = 13;
- hasReplicationMax() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int32 replication_max = 13;
- hasReplicationMax() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int32 replication_max = 8;
- hasReplicationMax() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int32 replication_max = 8;
- hasReplicationMax() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int32 replication_max = 8;
- hasReplicationMax() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_max = 21;
- hasReplicationMax() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int32 replication_max = 21;
- hasReplicationMax() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int32 replication_max = 21;
- hasReplicationMin() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationMin = 5;
- hasReplicationMin() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int32 replicationMin = 5;
- hasReplicationMin() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int32 replicationMin = 5;
- hasReplicationMin() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 replicationMin = 30;
- hasReplicationMin() - Method in class alluxio.grpc.FileInfo
-
optional int32 replicationMin = 30;
- hasReplicationMin() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int32 replicationMin = 30;
- hasReplicationMin() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional int32 replicationMin = 8;
- hasReplicationMin() - Method in class alluxio.grpc.SetAttributePOptions
-
optional int32 replicationMin = 8;
- hasReplicationMin() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional int32 replicationMin = 8;
- hasReplicationMin() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_min = 21;
- hasReplicationMin() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int32 replication_min = 21;
- hasReplicationMin() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int32 replication_min = 21;
- hasReplicationMin() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 replication_min = 14;
- hasReplicationMin() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int32 replication_min = 14;
- hasReplicationMin() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int32 replication_min = 14;
- hasReplicationMin() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int32 replication_min = 9;
- hasReplicationMin() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional int32 replication_min = 9;
- hasReplicationMin() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional int32 replication_min = 9;
- hasReplicationMin() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_min = 22;
- hasReplicationMin() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int32 replication_min = 22;
- hasReplicationMin() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int32 replication_min = 22;
- hasReport() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- hasReport() - Method in class alluxio.grpc.GetConfigReportPResponse
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- hasReport() - Method in interface alluxio.grpc.GetConfigReportPResponseOrBuilder
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- hasRequestBody() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
optional bytes request_body = 1;
- hasRequestBody() - Method in class alluxio.grpc.SubmitJobPRequest
-
optional bytes request_body = 1;
- hasRequestBody() - Method in interface alluxio.grpc.SubmitJobPRequestOrBuilder
-
optional bytes request_body = 1;
- hasRequestHeader() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- hasRequestHeader() - Method in class alluxio.grpc.TransportMessage
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- hasRequestHeader() - Method in interface alluxio.grpc.TransportMessageOrBuilder
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- hasRequestId() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
optional int64 requestId = 1;
- hasRequestId() - Method in class alluxio.grpc.MessagingRequestHeader
-
optional int64 requestId = 1;
- hasRequestId() - Method in interface alluxio.grpc.MessagingRequestHeaderOrBuilder
-
optional int64 requestId = 1;
- hasRequestId() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
optional int64 requestId = 1;
- hasRequestId() - Method in class alluxio.grpc.MessagingResponseHeader
-
optional int64 requestId = 1;
- hasRequestId() - Method in interface alluxio.grpc.MessagingResponseHeaderOrBuilder
-
optional int64 requestId = 1;
- hasResponseHeader() - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- hasResponseHeader() - Method in class alluxio.grpc.TransportMessage
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- hasResponseHeader() - Method in interface alluxio.grpc.TransportMessageOrBuilder
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- hasResult() - Method in class alluxio.grpc.JobInfo.Builder
-
optional bytes result = 9;
- hasResult() - Method in class alluxio.grpc.JobInfo
-
optional bytes result = 9;
- hasResult() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional bytes result = 9;
- hasRetryable() - Method in class alluxio.grpc.BlockStatus.Builder
-
optional bool retryable = 4;
- hasRetryable() - Method in class alluxio.grpc.BlockStatus
-
optional bool retryable = 4;
- hasRetryable() - Method in interface alluxio.grpc.BlockStatusOrBuilder
-
optional bool retryable = 4;
- hasRetryable() - Method in class alluxio.grpc.FileFailure.Builder
-
optional bool retryable = 4;
- hasRetryable() - Method in class alluxio.grpc.FileFailure
-
optional bool retryable = 4;
- hasRetryable() - Method in interface alluxio.grpc.FileFailureOrBuilder
-
optional bool retryable = 4;
- hasRetryable() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional bool retryable = 4;
- hasRetryable() - Method in class alluxio.grpc.LoadFileFailure
-
optional bool retryable = 4;
- hasRetryable() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
-
optional bool retryable = 4;
- hasRetryable() - Method in class alluxio.grpc.RouteFailure.Builder
-
optional bool retryable = 4;
- hasRetryable() - Method in class alluxio.grpc.RouteFailure
-
optional bool retryable = 4;
- hasRetryable() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
optional bool retryable = 4;
- hasRevision() - Method in class alluxio.grpc.BuildVersion.Builder
-
the git revision at the time of building
- hasRevision() - Method in class alluxio.grpc.BuildVersion
-
the git revision at the time of building
- hasRevision() - Method in interface alluxio.grpc.BuildVersionOrBuilder
-
the git revision at the time of building
- hasRevision() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string revision = 5;
- hasRevision() - Method in class alluxio.grpc.RegisterMasterPOptions
-
optional string revision = 5;
- hasRevision() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
optional string revision = 5;
- hasRoute() - Method in class alluxio.grpc.RouteFailure.Builder
-
required .alluxio.grpc.block.Route route = 1;
- hasRoute() - Method in class alluxio.grpc.RouteFailure
-
required .alluxio.grpc.block.Route route = 1;
- hasRoute() - Method in interface alluxio.grpc.RouteFailureOrBuilder
-
required .alluxio.grpc.block.Route route = 1;
- hasRpcPort() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int32 rpcPort = 3;
- hasRpcPort() - Method in class alluxio.grpc.MasterInfo
-
optional int32 rpcPort = 3;
- hasRpcPort() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional int32 rpcPort = 3;
- hasRpcPort() - Method in class alluxio.grpc.NetAddress.Builder
-
optional int32 rpcPort = 2;
- hasRpcPort() - Method in class alluxio.grpc.NetAddress
-
optional int32 rpcPort = 2;
- hasRpcPort() - Method in interface alluxio.grpc.NetAddressOrBuilder
-
optional int32 rpcPort = 2;
- hasRpcPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 rpcPort = 2;
- hasRpcPort() - Method in class alluxio.grpc.WorkerNetAddress
-
optional int32 rpcPort = 2;
- hasRpcPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional int32 rpcPort = 2;
- hasRunAsync() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool runAsync = 2;
- hasRunAsync() - Method in class alluxio.grpc.BackupPOptions
-
optional bool runAsync = 2;
- hasRunAsync() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
-
optional bool runAsync = 2;
- hasRunTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- hasRunTaskCommand() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- hasRunTaskCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- hasS3SyntaxOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- hasS3SyntaxOptions() - Method in class alluxio.grpc.RenamePOptions
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- hasS3SyntaxOptions() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- hasSafeMode() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional bool safeMode = 4;
- hasSafeMode() - Method in class alluxio.grpc.MasterInfo
-
optional bool safeMode = 4;
- hasSafeMode() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional bool safeMode = 4;
- hasSameLock(LockResource) - Method in class alluxio.resource.LockResource
-
Returns true if the other
LockResource
contains the same lock.
- hasScale() - Method in class alluxio.grpc.table.Decimal.Builder
-
force using scale first in Decimal.compareTo
- hasScale() - Method in class alluxio.grpc.table.Decimal
-
force using scale first in Decimal.compareTo
- hasScale() - Method in interface alluxio.grpc.table.DecimalOrBuilder
-
force using scale first in Decimal.compareTo
- hasScanCompleted() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanCompleted = 4;
- hasScanCompleted() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 scanCompleted = 4;
- hasScanCompleted() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 scanCompleted = 4;
- hasScanPendingAction() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanPendingAction = 3;
- hasScanPendingAction() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 scanPendingAction = 3;
- hasScanPendingAction() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 scanPendingAction = 3;
- hasScanStartedMs() - Method in class alluxio.grpc.PolicyStatus.Builder
-
scan status
- hasScanStartedMs() - Method in class alluxio.grpc.PolicyStatus
-
scan status
- hasScanStartedMs() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
scan status
- hasScanTotal() - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanTotal = 2;
- hasScanTotal() - Method in class alluxio.grpc.PolicyStatus
-
optional int64 scanTotal = 2;
- hasScanTotal() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
-
optional int64 scanTotal = 2;
- hasSchema() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Schema schema = 5;
- hasSchema() - Method in class alluxio.grpc.table.TableInfo
-
optional .alluxio.grpc.table.Schema schema = 5;
- hasSchema() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional .alluxio.grpc.table.Schema schema = 5;
- hasScheme() - Method in class alluxio.AlluxioURI
-
- hasSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
optional int64 sequence_number = 2;
- hasSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
optional int64 sequence_number = 2;
- hasSequenceNumber() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
-
optional int64 sequence_number = 2;
- hasSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
shared fields.
- hasSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
shared fields.
- hasSequenceNumber() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
shared fields.
- hasSerde() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string serde = 1;
- hasSerde() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
optional string serde = 1;
- hasSerde() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
optional string serde = 1;
- hasServerAddress() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- hasServerAddress() - Method in class alluxio.grpc.AddQuorumServerRequest
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- hasServerAddress() - Method in interface alluxio.grpc.AddQuorumServerRequestOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- hasServerAddress() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- hasServerAddress() - Method in class alluxio.grpc.QuorumServerInfo
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- hasServerAddress() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- hasServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- hasServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- hasServerAddress() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- hasServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- hasServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- hasServerAddress() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- hasServerState() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
- hasServerState() - Method in class alluxio.grpc.QuorumServerInfo
-
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
- hasServerState() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
-
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
- hasServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
The purpose of this field is to make grpc service on standby masters work without
making client changes and keeps backwards compatibility.
- hasServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest
-
The purpose of this field is to make grpc service on standby masters work without
making client changes and keeps backwards compatibility.
- hasServiceType() - Method in interface alluxio.grpc.GetServiceVersionPRequestOrBuilder
-
The purpose of this field is to make grpc service on standby masters work without
making client changes and keeps backwards compatibility.
- hasSetAcl() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- hasSetAcl() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- hasSetAcl() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- hasSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- hasSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- hasSetAttribute() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- hasSetTaskPoolSizeCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- hasSetTaskPoolSizeCommand() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- hasSetTaskPoolSizeCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- hasShared() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional bool shared = 7;
- hasShared() - Method in class alluxio.grpc.MountPointInfo
-
optional bool shared = 7;
- hasShared() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional bool shared = 7;
- hasShared() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional bool shared = 3;
- hasShared() - Method in class alluxio.grpc.MountPOptions
-
optional bool shared = 3;
- hasShared() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
optional bool shared = 3;
- hasShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional bool shared = 5;
- hasShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional bool shared = 5;
- hasShared() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional bool shared = 5;
- hasShouldPersistTime() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 should_persist_time = 27;
- hasShouldPersistTime() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 should_persist_time = 27;
- hasShouldPersistTime() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 should_persist_time = 27;
- hasShouldPersistTime() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 should_persist_time = 28;
- hasShouldPersistTime() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 should_persist_time = 28;
- hasShouldPersistTime() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 should_persist_time = 28;
- hasSkewed() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional bool skewed = 4;
- hasSkewed() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional bool skewed = 4;
- hasSkewed() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional bool skewed = 4;
- hasSkipIfExists() - Method in class alluxio.grpc.LoadFileRequest.Builder
-
optional bool skip_if_exists = 4;
- hasSkipIfExists() - Method in class alluxio.grpc.LoadFileRequest
-
optional bool skip_if_exists = 4;
- hasSkipIfExists() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
-
optional bool skip_if_exists = 4;
- hasSkipIfExists() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool skipIfExists = 5;
- hasSkipIfExists() - Method in class alluxio.grpc.LoadJobPOptions
-
optional bool skipIfExists = 5;
- hasSkipIfExists() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
-
optional bool skipIfExists = 5;
- hasSkipIfExists() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional bool skip_if_exists = 10;
- hasSkipIfExists() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional bool skip_if_exists = 10;
- hasSkipIfExists() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional bool skip_if_exists = 10;
- hasSnapshotIndex() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional int64 snapshotIndex = 2;
- hasSnapshotIndex() - Method in class alluxio.grpc.SnapshotData
-
optional int64 snapshotIndex = 2;
- hasSnapshotIndex() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
optional int64 snapshotIndex = 2;
- hasSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional int64 snapshotIndex = 2;
- hasSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata
-
optional int64 snapshotIndex = 2;
- hasSnapshotIndex() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
-
optional int64 snapshotIndex = 2;
- hasSnapshotInfo() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- hasSnapshotInfo() - Method in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- hasSnapshotInfo() - Method in interface alluxio.grpc.GetSnapshotInfoRequestOrBuilder
-
Deprecated.
- hasSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- hasSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest
-
Deprecated.
- hasSnapshotInfoRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
Deprecated.
- hasSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- hasSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- hasSnapshotInfoResponse() - Method in interface alluxio.grpc.JournalQueryResponseOrBuilder
-
Deprecated.
- hasSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- hasSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest
-
Deprecated.
- hasSnapshotRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
Deprecated.
- hasSnapshotTerm() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional int64 snapshotTerm = 1;
- hasSnapshotTerm() - Method in class alluxio.grpc.SnapshotData
-
optional int64 snapshotTerm = 1;
- hasSnapshotTerm() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
optional int64 snapshotTerm = 1;
- hasSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional int64 snapshotTerm = 1;
- hasSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata
-
optional int64 snapshotTerm = 1;
- hasSnapshotTerm() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
-
optional int64 snapshotTerm = 1;
- hasSource() - Method in class alluxio.grpc.ClientMetrics.Builder
-
optional string source = 1;
- hasSource() - Method in class alluxio.grpc.ClientMetrics
-
optional string source = 1;
- hasSource() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
-
optional string source = 1;
- hasSource() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string source = 2;
- hasSource() - Method in class alluxio.grpc.ConfigProperty
-
optional string source = 2;
- hasSource() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
-
optional string source = 2;
- hasSource() - Method in class alluxio.grpc.Metric.Builder
-
optional string source = 2;
- hasSource() - Method in class alluxio.grpc.Metric
-
optional string source = 2;
- hasSource() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional string source = 2;
- hasSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- hasSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- hasSourceHost() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- hasSourceHost() - Method in class alluxio.grpc.CacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- hasSourceHost() - Method in class alluxio.grpc.CacheRequest
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- hasSourceHost() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- hasSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- hasSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- hasSourceHost() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- hasSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int32 source_port = 3;
- hasSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest
-
optional int32 source_port = 3;
- hasSourcePort() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
-
optional int32 source_port = 3;
- hasSourcePort() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int32 source_port = 3;
- hasSourcePort() - Method in class alluxio.grpc.CacheRequest
-
optional int32 source_port = 3;
- hasSourcePort() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional int32 source_port = 3;
- hasSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int32 source_port = 3;
- hasSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
optional int32 source_port = 3;
- hasSourcePort() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
-
optional int32 source_port = 3;
- hasSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional int64 space_to_reserve = 10;
- hasSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand
-
optional int64 space_to_reserve = 10;
- hasSpaceToReserve() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional int64 space_to_reserve = 10;
- hasSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int64 space_to_reserve = 4;
- hasSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
optional int64 space_to_reserve = 4;
- hasSpaceToReserve() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
-
optional int64 space_to_reserve = 4;
- hasSpec() - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
optional string spec = 1;
- hasSpec() - Method in class alluxio.grpc.table.LayoutSpec
-
optional string spec = 1;
- hasSpec() - Method in interface alluxio.grpc.table.LayoutSpecOrBuilder
-
optional string spec = 1;
- hasSpec() - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
optional string spec = 1;
- hasSpec() - Method in class alluxio.grpc.table.PartitionSpec
-
optional string spec = 1;
- hasSpec() - Method in interface alluxio.grpc.table.PartitionSpecOrBuilder
-
optional string spec = 1;
- hasSrc() - Method in class alluxio.grpc.Route.Builder
-
required string src = 1;
- hasSrc() - Method in class alluxio.grpc.Route
-
required string src = 1;
- hasSrc() - Method in interface alluxio.grpc.RouteOrBuilder
-
required string src = 1;
- hasSrc() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string src = 1;
- hasSrc() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required string src = 1;
- hasSrc() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required string src = 1;
- hasSrc() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string src = 1;
- hasSrc() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required string src = 1;
- hasSrc() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required string src = 1;
- hasSrcPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string srcPath = 2;
- hasSrcPath() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string srcPath = 2;
- hasSrcPath() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string srcPath = 2;
- hasStartAfter() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Start the listing after this path.
- hasStartAfter() - Method in class alluxio.grpc.ListStatusPartialPOptions
-
Start the listing after this path.
- hasStartAfter() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
-
Start the listing after this path.
- hasStartTime() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional int64 startTime = 3;
- hasStartTime() - Method in class alluxio.grpc.JobMasterStatus
-
optional int64 startTime = 3;
- hasStartTime() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional int64 startTime = 3;
- hasStartTime() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional int64 startTime = 2;
- hasStartTime() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
optional int64 startTime = 2;
- hasStartTime() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
-
optional int64 startTime = 2;
- hasStartTime() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional int64 startTime = 3;
- hasStartTime() - Method in class alluxio.grpc.ProxyStatus
-
optional int64 startTime = 3;
- hasStartTime() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional int64 startTime = 3;
- hasStartTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int64 startTimeMs = 5;
- hasStartTimeMs() - Method in class alluxio.grpc.MasterInfo
-
optional int64 startTimeMs = 5;
- hasStartTimeMs() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional int64 startTimeMs = 5;
- hasStartTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional int64 startTimeMs = 2;
- hasStartTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
optional int64 startTimeMs = 2;
- hasStartTimeMs() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
-
optional int64 startTimeMs = 2;
- hasStartTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional int64 startTimeMs = 2;
- hasStartTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions
-
optional int64 startTimeMs = 2;
- hasStartTimeMs() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
optional int64 startTimeMs = 2;
- hasStartTimeMs() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 startTimeMs = 7;
- hasStartTimeMs() - Method in class alluxio.grpc.WorkerInfo
-
optional int64 startTimeMs = 7;
- hasStartTimeMs() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional int64 startTimeMs = 7;
- hasState() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional string state = 1;
- hasState() - Method in class alluxio.grpc.JobMasterStatus
-
optional string state = 1;
- hasState() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional string state = 1;
- hasState() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string state = 3;
- hasState() - Method in class alluxio.grpc.MasterVersion
-
optional string state = 3;
- hasState() - Method in interface alluxio.grpc.MasterVersionOrBuilder
-
optional string state = 3;
- hasState() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional string state = 2;
- hasState() - Method in class alluxio.grpc.ProxyStatus
-
optional string state = 2;
- hasState() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional string state = 2;
- hasState() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional string state = 4;
- hasState() - Method in class alluxio.grpc.WorkerInfo
-
optional string state = 4;
- hasState() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional string state = 4;
- hasState() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 3;
- hasState() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required .alluxio.proto.journal.PJobState state = 3;
- hasState() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required .alluxio.proto.journal.PJobState state = 3;
- hasState() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 2;
- hasState() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required .alluxio.proto.journal.PJobState state = 2;
- hasState() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required .alluxio.proto.journal.PJobState state = 2;
- hasState() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 3;
- hasState() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required .alluxio.proto.journal.PJobState state = 3;
- hasState() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required .alluxio.proto.journal.PJobState state = 3;
- hasStatus() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.Status status = 4;
- hasStatus() - Method in class alluxio.grpc.CmdSummary
-
optional .alluxio.grpc.job.Status status = 4;
- hasStatus() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional .alluxio.grpc.job.Status status = 4;
- hasStatus() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
optional .alluxio.grpc.meta.ConfigStatus status = 3;
- hasStatus() - Method in class alluxio.grpc.ConfigCheckReport
-
optional .alluxio.grpc.meta.ConfigStatus status = 3;
- hasStatus() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
-
optional .alluxio.grpc.meta.ConfigStatus status = 3;
- hasStatus() - Method in class alluxio.grpc.CopyResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in class alluxio.grpc.CopyResponse
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in interface alluxio.grpc.CopyResponseOrBuilder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- hasStatus() - Method in class alluxio.grpc.GetPolicyStatusPResponse
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- hasStatus() - Method in interface alluxio.grpc.GetPolicyStatusPResponseOrBuilder
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- hasStatus() - Method in class alluxio.grpc.JobInfo.Builder
-
optional .alluxio.grpc.job.Status status = 4;
- hasStatus() - Method in class alluxio.grpc.JobInfo
-
optional .alluxio.grpc.job.Status status = 4;
- hasStatus() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional .alluxio.grpc.job.Status status = 4;
- hasStatus() - Method in class alluxio.grpc.JobProgress.Builder
-
optional .alluxio.grpc.job.Status status = 7;
- hasStatus() - Method in class alluxio.grpc.JobProgress
-
optional .alluxio.grpc.job.Status status = 7;
- hasStatus() - Method in interface alluxio.grpc.JobProgressOrBuilder
-
optional .alluxio.grpc.job.Status status = 7;
- hasStatus() - Method in class alluxio.grpc.LoadFileResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in class alluxio.grpc.LoadFileResponse
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in class alluxio.grpc.LoadResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in class alluxio.grpc.LoadResponse
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in interface alluxio.grpc.LoadResponseOrBuilder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in class alluxio.grpc.MoveResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in class alluxio.grpc.MoveResponse
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in interface alluxio.grpc.MoveResponseOrBuilder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- hasStatus() - Method in class alluxio.grpc.StatusSummary.Builder
-
optional .alluxio.grpc.job.Status status = 1;
- hasStatus() - Method in class alluxio.grpc.StatusSummary
-
optional .alluxio.grpc.job.Status status = 1;
- hasStatus() - Method in interface alluxio.grpc.StatusSummaryOrBuilder
-
optional .alluxio.grpc.job.Status status = 1;
- hasStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- hasStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- hasStatus() - Method in interface alluxio.grpc.table.SyncDatabasePResponseOrBuilder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- hasStatus() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional .alluxio.proto.status.PStatus status = 1;
- hasStatus() - Method in class alluxio.proto.dataserver.Protocol.Response
-
optional .alluxio.proto.status.PStatus status = 1;
- hasStatus() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
-
optional .alluxio.proto.status.PStatus status = 1;
- hasStatus(AlluxioURI) - Method in class alluxio.underfs.UfsStatusCache
-
Check if a status has been loaded in the cache for the given AlluxioURI.
- hasStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- hasStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- hasStorage() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- hasStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- hasStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- hasStorageFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- hasStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- hasStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- hasStringStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- hasStringType() - Method in class alluxio.grpc.table.Value.Builder
-
string string_type = 3;
- hasStringType() - Method in class alluxio.grpc.table.Value
-
string string_type = 3;
- hasStringType() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
string string_type = 3;
- hasStringValue() - Method in class alluxio.grpc.MetricValue.Builder
-
optional string stringValue = 2;
- hasStringValue() - Method in class alluxio.grpc.MetricValue
-
optional string stringValue = 2;
- hasStringValue() - Method in interface alluxio.grpc.MetricValueOrBuilder
-
optional string stringValue = 2;
- hasSubCommand() - Method in interface alluxio.cli.Command
-
If a command has sub-commands, the first argument should be the sub-command's name,
all arguments and options will be parsed for the sub-command.
- hasSubject() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional string subject = 2;
- hasSubject() - Method in class alluxio.grpc.PAclEntry
-
optional string subject = 2;
- hasSubject() - Method in interface alluxio.grpc.PAclEntryOrBuilder
-
optional string subject = 2;
- hasSubject() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional string subject = 2;
- hasSubject() - Method in class alluxio.proto.shared.Acl.AclEntry
-
optional string subject = 2;
- hasSubject() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
-
optional string subject = 2;
- hasSubmissionTime() - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 submissionTime = 5;
- hasSubmissionTime() - Method in class alluxio.grpc.CmdSummary
-
optional int64 submissionTime = 5;
- hasSubmissionTime() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
-
optional int64 submissionTime = 5;
- hasSuccess() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
TODO(gpang): remove in favor of status
- hasSuccess() - Method in class alluxio.grpc.table.AttachDatabasePResponse
-
TODO(gpang): remove in favor of status
- hasSuccess() - Method in interface alluxio.grpc.table.AttachDatabasePResponseOrBuilder
-
TODO(gpang): remove in favor of status
- hasSuccess() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
optional bool success = 1;
- hasSuccess() - Method in class alluxio.grpc.table.DetachDatabasePResponse
-
optional bool success = 1;
- hasSuccess() - Method in interface alluxio.grpc.table.DetachDatabasePResponseOrBuilder
-
optional bool success = 1;
- hasSuccess() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
TODO(gpang): remove in favor of status
- hasSuccess() - Method in class alluxio.grpc.table.SyncDatabasePResponse
-
TODO(gpang): remove in favor of status
- hasSuccess() - Method in interface alluxio.grpc.table.SyncDatabasePResponseOrBuilder
-
TODO(gpang): remove in favor of status
- hasSummary() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- hasSummary() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- hasSummary() - Method in interface alluxio.grpc.GetJobServiceSummaryPResponseOrBuilder
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- hasSyncIntervalMs() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional int64 syncIntervalMs = 1;
- hasSyncIntervalMs() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
optional int64 syncIntervalMs = 1;
- hasSyncIntervalMs() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
-
optional int64 syncIntervalMs = 1;
- hasSyncParentNextTime() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool syncParentNextTime = 5;
- hasSyncParentNextTime() - Method in class alluxio.grpc.DeletePOptions
-
optional bool syncParentNextTime = 5;
- hasSyncParentNextTime() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional bool syncParentNextTime = 5;
- hasSyncpointPath() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- hasSyncpointPath() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
-
optional string syncpoint_path = 1;
- hasSyncpointPath() - Method in interface alluxio.proto.journal.File.AddSyncPointEntryOrBuilder
-
optional string syncpoint_path = 1;
- hasSyncpointPath() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- hasSyncpointPath() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
optional string syncpoint_path = 1;
- hasSyncpointPath() - Method in interface alluxio.proto.journal.File.RemoveSyncPointEntryOrBuilder
-
optional string syncpoint_path = 1;
- hasSyncStatus() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- hasSyncStatus() - Method in class alluxio.grpc.table.AttachDatabasePResponse
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- hasSyncStatus() - Method in interface alluxio.grpc.table.AttachDatabasePResponseOrBuilder
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- hasTableInfo() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- hasTableInfo() - Method in class alluxio.grpc.table.GetTablePResponse
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- hasTableInfo() - Method in interface alluxio.grpc.table.GetTablePResponseOrBuilder
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- hasTableName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
-
optional string table_name = 2;
- hasTableName() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
-
optional string table_name = 2;
- hasTableName() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.GetTablePRequest
-
optional string table_name = 2;
- hasTableName() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string table_name = 4;
- hasTableName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
-
optional string table_name = 4;
- hasTableName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
-
optional string table_name = 4;
- hasTableName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.ReadTablePRequest
-
optional string table_name = 2;
- hasTableName() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.TableInfo
-
optional string table_name = 2;
- hasTableName() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.TransformJobInfo
-
optional string table_name = 2;
- hasTableName() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string table_name = 2;
- hasTableName() - Method in class alluxio.grpc.table.TransformTablePRequest
-
optional string table_name = 2;
- hasTableName() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
-
optional string table_name = 2;
- hasTag() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
required string tag = 1;
- hasTag() - Method in class alluxio.grpc.UfsReadOptions
-
required string tag = 1;
- hasTag() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
-
required string tag = 1;
- hasTargetDirectory() - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional string targetDirectory = 2;
- hasTargetDirectory() - Method in class alluxio.grpc.BackupPRequest
-
optional string targetDirectory = 2;
- hasTargetDirectory() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
-
optional string targetDirectory = 2;
- hasTaskArgs() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional bytes taskArgs = 4;
- hasTaskArgs() - Method in class alluxio.grpc.RunTaskCommand
-
optional bytes taskArgs = 4;
- hasTaskArgs() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
-
optional bytes taskArgs = 4;
- hasTaskId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
optional int64 taskId = 2;
- hasTaskId() - Method in class alluxio.grpc.CancelTaskCommand
-
optional int64 taskId = 2;
- hasTaskId() - Method in interface alluxio.grpc.CancelTaskCommandOrBuilder
-
optional int64 taskId = 2;
- hasTaskId() - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional int64 taskId = 2;
- hasTaskId() - Method in class alluxio.grpc.RunTaskCommand
-
optional int64 taskId = 2;
- hasTaskId() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
-
optional int64 taskId = 2;
- hasTaskPoolSize() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 taskPoolSize = 5;
- hasTaskPoolSize() - Method in class alluxio.grpc.JobWorkerHealth
-
optional int32 taskPoolSize = 5;
- hasTaskPoolSize() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional int32 taskPoolSize = 5;
- hasTaskPoolSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
optional int32 taskPoolSize = 1;
- hasTaskPoolSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
-
optional int32 taskPoolSize = 1;
- hasTaskPoolSize() - Method in interface alluxio.grpc.SetTaskPoolSizeCommandOrBuilder
-
optional int32 taskPoolSize = 1;
- hasTempBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
-
Checks if the storage has a given temp block.
- hasTempBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
-
Checks if a temp block is in this storage dir.
- hasTempFile(String) - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
- hasTempUfsPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string temp_ufs_path = 23;
- hasTempUfsPath() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string temp_ufs_path = 23;
- hasTempUfsPath() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string temp_ufs_path = 23;
- hasTempUfsPath() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string tempUfsPath = 12;
- hasTempUfsPath() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string tempUfsPath = 12;
- hasTempUfsPath() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string tempUfsPath = 12;
- hasTempUfsPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string temp_ufs_path = 11;
- hasTempUfsPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional string temp_ufs_path = 11;
- hasTempUfsPath() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional string temp_ufs_path = 11;
- hasTier() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
This is only applicable for block write.
- hasTier() - Method in class alluxio.grpc.WriteRequestCommand
-
This is only applicable for block write.
- hasTier() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
This is only applicable for block write.
- hasTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int32 tier = 3;
- hasTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
optional int32 tier = 3;
- hasTier() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
-
optional int32 tier = 3;
- hasTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for block write.
- hasTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
This is only applicable for block write.
- hasTier() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
This is only applicable for block write.
- hasTier() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string tier = 2;
- hasTier() - Method in class alluxio.proto.meta.Block.BlockLocation
-
optional string tier = 2;
- hasTier() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
-
optional string tier = 2;
- hasTierAlias() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string tierAlias = 3;
- hasTierAlias() - Method in class alluxio.grpc.BlockLocation
-
optional string tierAlias = 3;
- hasTierAlias() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional string tierAlias = 3;
- hasTierAlias() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string tierAlias = 1;
- hasTierAlias() - Method in class alluxio.grpc.BlockStoreLocationProto
-
optional string tierAlias = 1;
- hasTierAlias() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
-
optional string tierAlias = 1;
- hasTierAlias() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the alias of the target tier
- hasTierAlias() - Method in class alluxio.grpc.CommitBlockPRequest
-
the alias of the target tier
- hasTierAlias() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the alias of the target tier
- hasTimeExpression() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string timeExpression = 4;
- hasTimeExpression() - Method in class alluxio.grpc.AddPolicyPOptions
-
optional string timeExpression = 4;
- hasTimeExpression() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
-
optional string timeExpression = 4;
- hasTransferId() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
required string transferId = 1;
- hasTransferId() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
-
required string transferId = 1;
- hasTransferId() - Method in interface alluxio.grpc.GetTransferLeaderMessagePRequestOrBuilder
-
required string transferId = 1;
- hasTransferId() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
required string transferId = 1;
- hasTransferId() - Method in class alluxio.grpc.TransferLeadershipPResponse
-
required string transferId = 1;
- hasTransferId() - Method in interface alluxio.grpc.TransferLeadershipPResponseOrBuilder
-
required string transferId = 1;
- hasTransMsg() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- hasTransMsg() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- hasTransMsg() - Method in interface alluxio.grpc.GetTransferLeaderMessagePResponseOrBuilder
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- hasTs() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
the timestamp in nanoseconds when this FileStatus is refreshed
- hasTs() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
-
the timestamp in nanoseconds when this FileStatus is refreshed
- hasTs() - Method in interface alluxio.proto.meta.DoraMeta.FileStatusOrBuilder
-
the timestamp in nanoseconds when this FileStatus is refreshed
- hasTtl() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 ttl = 15;
- hasTtl() - Method in class alluxio.grpc.FileInfo
-
optional int64 ttl = 15;
- hasTtl() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 ttl = 15;
- hasTtl() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional int64 ttl = 2;
- hasTtl() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
optional int64 ttl = 2;
- hasTtl() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
-
optional int64 ttl = 2;
- hasTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 ttl = 13;
- hasTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 ttl = 13;
- hasTtl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 ttl = 13;
- hasTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 ttl = 13;
- hasTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 ttl = 13;
- hasTtl() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 ttl = 13;
- hasTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 ttl = 4;
- hasTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional int64 ttl = 4;
- hasTtl() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional int64 ttl = 4;
- hasTtl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 ttl = 12;
- hasTtl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 ttl = 12;
- hasTtl() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 ttl = 12;
- hasTtl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 ttl = 4;
- hasTtl() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 ttl = 4;
- hasTtl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 ttl = 4;
- hasTtlAction() - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.TtlAction ttlAction = 22;
- hasTtlAction() - Method in class alluxio.grpc.FileInfo
-
optional .alluxio.grpc.TtlAction ttlAction = 22;
- hasTtlAction() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional .alluxio.grpc.TtlAction ttlAction = 22;
- hasTtlAction() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.TtlAction ttlAction = 3;
- hasTtlAction() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
-
optional .alluxio.grpc.TtlAction ttlAction = 3;
- hasTtlAction() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
-
optional .alluxio.grpc.TtlAction ttlAction = 3;
- hasTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
- hasTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
- hasTtlAction() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
- hasTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
- hasTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
- hasTtlAction() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
- hasTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
- hasTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
- hasTtlAction() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
- hasTtlAction() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
- hasTtlAction() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
- hasTtlAction() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
- hasTtlAction() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.grpc.TtlAction ttl_action = 5;
- hasTtlAction() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional .alluxio.grpc.TtlAction ttl_action = 5;
- hasTtlAction() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional .alluxio.grpc.TtlAction ttl_action = 5;
- hasTxId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
optional int64 tx_id = 2;
- hasTxId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
-
optional int64 tx_id = 2;
- hasTxId() - Method in interface alluxio.proto.journal.File.ActiveSyncTxIdEntryOrBuilder
-
optional int64 tx_id = 2;
- hasType() - Method in class alluxio.grpc.JobDescription.Builder
-
required string type = 1;
- hasType() - Method in class alluxio.grpc.JobDescription
-
required string type = 1;
- hasType() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
-
required string type = 1;
- hasType() - Method in class alluxio.grpc.JobInfo.Builder
-
optional .alluxio.grpc.job.JobType type = 8;
- hasType() - Method in class alluxio.grpc.JobInfo
-
optional .alluxio.grpc.job.JobType type = 8;
- hasType() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional .alluxio.grpc.job.JobType type = 8;
- hasType() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional .alluxio.grpc.file.PAclEntryType type = 1;
- hasType() - Method in class alluxio.grpc.PAclEntry
-
optional .alluxio.grpc.file.PAclEntryType type = 1;
- hasType() - Method in interface alluxio.grpc.PAclEntryOrBuilder
-
optional .alluxio.grpc.file.PAclEntryType type = 1;
- hasType() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string type = 3;
- hasType() - Method in class alluxio.grpc.table.FieldSchema
-
optional string type = 3;
- hasType() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional string type = 3;
- hasType() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
- hasType() - Method in class alluxio.grpc.table.TableInfo
-
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
- hasType() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
- hasType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional .alluxio.grpc.block.RequestType type = 1;
- hasType() - Method in class alluxio.grpc.WriteRequestCommand
-
optional .alluxio.grpc.block.RequestType type = 1;
- hasType() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
-
optional .alluxio.grpc.block.RequestType type = 1;
- hasType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
- hasType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
-
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
- hasType() - Method in interface alluxio.proto.dataserver.Protocol.ReadResponseOrBuilder
-
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
- hasType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional .alluxio.proto.dataserver.RequestType type = 1;
- hasType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
-
optional .alluxio.proto.dataserver.RequestType type = 1;
- hasType() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
-
optional .alluxio.proto.dataserver.RequestType type = 1;
- hasType() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional .alluxio.proto.shared.AclEntryType type = 1;
- hasType() - Method in class alluxio.proto.shared.Acl.AclEntry
-
optional .alluxio.proto.shared.AclEntryType type = 1;
- hasType() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
-
optional .alluxio.proto.shared.AclEntryType type = 1;
- hasUdbConnectionUri() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_connection_uri = 2;
- hasUdbConnectionUri() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string udb_connection_uri = 2;
- hasUdbConnectionUri() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string udb_connection_uri = 2;
- hasUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_db_name = 3;
- hasUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string udb_db_name = 3;
- hasUdbDbName() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string udb_db_name = 3;
- hasUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_type = 1;
- hasUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
optional string udb_type = 1;
- hasUdbType() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
optional string udb_type = 1;
- hasUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 ufsCapacityBytes = 3 [default = -1];
- hasUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo
-
optional int64 ufsCapacityBytes = 3 [default = -1];
- hasUfsCapacityBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional int64 ufsCapacityBytes = 3 [default = -1];
- hasUfsFileStatus() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- hasUfsFileStatus() - Method in class alluxio.grpc.UfsStatus
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- hasUfsFileStatus() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- hasUfsFingerprint() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsFingerprint = 26;
- hasUfsFingerprint() - Method in class alluxio.grpc.FileInfo
-
optional string ufsFingerprint = 26;
- hasUfsFingerprint() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string ufsFingerprint = 26;
- hasUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional string ufs_fingerprint = 5;
- hasUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
optional string ufs_fingerprint = 5;
- hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
optional string ufs_fingerprint = 5;
- hasUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string ufs_fingerprint = 18;
- hasUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional string ufs_fingerprint = 18;
- hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional string ufs_fingerprint = 18;
- hasUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string ufs_fingerprint = 10;
- hasUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry
-
optional string ufs_fingerprint = 10;
- hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
-
optional string ufs_fingerprint = 10;
- hasUfsFingerprint() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string ufs_fingerprint = 15;
- hasUfsFingerprint() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional string ufs_fingerprint = 15;
- hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional string ufs_fingerprint = 15;
- hasUfsFingerprint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string ufs_fingerprint = 11;
- hasUfsFingerprint() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional string ufs_fingerprint = 11;
- hasUfsFingerprint() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional string ufs_fingerprint = 11;
- hasUfsFullPath() - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string ufs_full_path = 8;
- hasUfsFullPath() - Method in class alluxio.grpc.UfsStatus
-
optional string ufs_full_path = 8;
- hasUfsFullPath() - Method in interface alluxio.grpc.UfsStatusOrBuilder
-
optional string ufs_full_path = 8;
- hasUfsInfo() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- hasUfsInfo() - Method in class alluxio.grpc.GetUfsInfoPResponse
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- hasUfsInfo() - Method in interface alluxio.grpc.GetUfsInfoPResponseOrBuilder
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- hasUfsLength() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional int64 ufsLength = 1;
- hasUfsLength() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional int64 ufsLength = 1;
- hasUfsLength() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional int64 ufsLength = 1;
- hasUfsMode() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
- hasUfsMode() - Method in class alluxio.grpc.UpdateUfsModePOptions
-
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
- hasUfsMode() - Method in interface alluxio.grpc.UpdateUfsModePOptionsOrBuilder
-
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
- hasUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
- hasUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
- hasUfsMode() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
-
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
- hasUfsPath() - Method in class alluxio.grpc.Block.Builder
-
optional string ufs_path = 3;
- hasUfsPath() - Method in class alluxio.grpc.Block
-
optional string ufs_path = 3;
- hasUfsPath() - Method in interface alluxio.grpc.BlockOrBuilder
-
optional string ufs_path = 3;
- hasUfsPath() - Method in class alluxio.grpc.File.Builder
-
optional string ufs_path = 2;
- hasUfsPath() - Method in class alluxio.grpc.File
-
optional string ufs_path = 2;
- hasUfsPath() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsPath = 4;
- hasUfsPath() - Method in class alluxio.grpc.FileInfo
-
optional string ufsPath = 4;
- hasUfsPath() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string ufsPath = 4;
- hasUfsPath() - Method in interface alluxio.grpc.FileOrBuilder
-
optional string ufs_path = 2;
- hasUfsPath() - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of the under file system
- hasUfsPath() - Method in class alluxio.grpc.MountPRequest
-
the path of the under file system
- hasUfsPath() - Method in interface alluxio.grpc.MountPRequestOrBuilder
-
the path of the under file system
- hasUfsPath() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
the ufs path
- hasUfsPath() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
the ufs path
- hasUfsPath() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
-
the ufs path
- hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string ufs_path = 1;
- hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
-
optional string ufs_path = 1;
- hasUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
-
optional string ufs_path = 1;
- hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional string ufs_path = 1;
- hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
optional string ufs_path = 1;
- hasUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
optional string ufs_path = 1;
- hasUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string ufs_path = 2;
- hasUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
-
optional string ufs_path = 2;
- hasUfsPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
-
optional string ufs_path = 2;
- hasUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
optional string ufsPath = 1;
- hasUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
-
optional string ufsPath = 1;
- hasUfsPath() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
-
optional string ufsPath = 1;
- hasUfsReadOptions() - Method in class alluxio.grpc.CopyRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- hasUfsReadOptions() - Method in class alluxio.grpc.CopyRequest
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- hasUfsReadOptions() - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- hasUfsReadOptions() - Method in class alluxio.grpc.MoveRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- hasUfsReadOptions() - Method in class alluxio.grpc.MoveRequest
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- hasUfsReadOptions() - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- hasUfsReadWorkerLocation() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- hasUfsReadWorkerLocation() - Method in class alluxio.grpc.OpenFilePOptions
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- hasUfsReadWorkerLocation() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- hasUfsStatus() - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- hasUfsStatus() - Method in class alluxio.grpc.LoadFileFailure
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- hasUfsStatus() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- hasUfsType() - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsType = 35;
- hasUfsType() - Method in class alluxio.grpc.FileInfo
-
optional string ufsType = 35;
- hasUfsType() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional string ufsType = 35;
- hasUfsType() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsType = 2;
- hasUfsType() - Method in class alluxio.grpc.MountPointInfo
-
optional string ufsType = 2;
- hasUfsType() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional string ufsType = 2;
- hasUfsUri() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
required string ufsUri = 1;
- hasUfsUri() - Method in class alluxio.grpc.GetMountIdPRequest
-
required string ufsUri = 1;
- hasUfsUri() - Method in interface alluxio.grpc.GetMountIdPRequestOrBuilder
-
required string ufsUri = 1;
- hasUfsUri() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsUri = 1;
- hasUfsUri() - Method in class alluxio.grpc.MountPointInfo
-
optional string ufsUri = 1;
- hasUfsUri() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional string ufsUri = 1;
- hasUfsUri() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
optional string ufsUri = 1;
- hasUfsUri() - Method in class alluxio.grpc.ReverseResolvePRequest
-
optional string ufsUri = 1;
- hasUfsUri() - Method in interface alluxio.grpc.ReverseResolvePRequestOrBuilder
-
optional string ufsUri = 1;
- hasUfsUsedBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 ufsUsedBytes = 4 [default = -1];
- hasUfsUsedBytes() - Method in class alluxio.grpc.MountPointInfo
-
optional int64 ufsUsedBytes = 4 [default = -1];
- hasUfsUsedBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
-
optional int64 ufsUsedBytes = 4 [default = -1];
- hasUnchecked() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool unchecked = 3;
- hasUnchecked() - Method in class alluxio.grpc.DeletePOptions
-
optional bool unchecked = 3;
- hasUnchecked() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional bool unchecked = 3;
- hasUnfinishedTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 unfinishedTasks = 7;
- hasUnfinishedTasks() - Method in class alluxio.grpc.JobWorkerHealth
-
optional int32 unfinishedTasks = 7;
- hasUnfinishedTasks() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional int32 unfinishedTasks = 7;
- hasUnscaled() - Method in class alluxio.grpc.table.Decimal.Builder
-
required bytes unscaled = 2;
- hasUnscaled() - Method in class alluxio.grpc.table.Decimal
-
required bytes unscaled = 2;
- hasUnscaled() - Method in interface alluxio.grpc.table.DecimalOrBuilder
-
required bytes unscaled = 2;
- hasUnused1() - Method in class alluxio.grpc.JobInfo.Builder
-
formerly result
- hasUnused1() - Method in class alluxio.grpc.JobInfo
-
formerly result
- hasUnused1() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
formerly result
- hasUpdateInode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- hasUpdateInode() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- hasUpdateInode() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- hasUpdateInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- hasUpdateInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- hasUpdateInodeDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- hasUpdateInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- hasUpdateInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- hasUpdateInodeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- hasUpdateLastAccessTime() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional bool updateLastAccessTime = 4 [default = true];
- hasUpdateLastAccessTime() - Method in class alluxio.grpc.OpenFilePOptions
-
optional bool updateLastAccessTime = 4 [default = true];
- hasUpdateLastAccessTime() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional bool updateLastAccessTime = 4 [default = true];
- hasUpdateTimestamps() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional bool updateTimestamps = 4 [default = true];
- hasUpdateTimestamps() - Method in class alluxio.grpc.GetStatusPOptions
-
optional bool updateTimestamps = 4 [default = true];
- hasUpdateTimestamps() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional bool updateTimestamps = 4 [default = true];
- hasUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- hasUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- hasUpdateUfsMode() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- hasUpTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int64 upTimeMs = 6;
- hasUpTimeMs() - Method in class alluxio.grpc.MasterInfo
-
optional int64 upTimeMs = 6;
- hasUpTimeMs() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional int64 upTimeMs = 6;
- hasUri() - Method in class alluxio.grpc.UfsInfo.Builder
-
optional string uri = 1;
- hasUri() - Method in class alluxio.grpc.UfsInfo
-
optional string uri = 1;
- hasUri() - Method in interface alluxio.grpc.UfsInfoOrBuilder
-
optional string uri = 1;
- hasUsedBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 usedBytes = 6;
- hasUsedBytes() - Method in class alluxio.grpc.BlockMasterInfo
-
optional int64 usedBytes = 6;
- hasUsedBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
-
optional int64 usedBytes = 6;
- hasUsedBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 usedBytes = 6;
- hasUsedBytes() - Method in class alluxio.grpc.WorkerInfo
-
optional int64 usedBytes = 6;
- hasUsedBytes() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
-
optional int64 usedBytes = 6;
- hasUsedBytesOnTier() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the space used in bytes on the target tier
- hasUsedBytesOnTier() - Method in class alluxio.grpc.CommitBlockPRequest
-
the space used in bytes on the target tier
- hasUsedBytesOnTier() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the space used in bytes on the target tier
- hasUseMultipartUpload() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool useMultipartUpload = 17;
- hasUseMultipartUpload() - Method in class alluxio.grpc.CreateFilePOptions
-
optional bool useMultipartUpload = 17;
- hasUseMultipartUpload() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional bool useMultipartUpload = 17;
- hasUser() - Method in class alluxio.grpc.UfsReadOptions.Builder
-
optional string user = 4;
- hasUser() - Method in class alluxio.grpc.UfsReadOptions
-
optional string user = 4;
- hasUser() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
-
optional string user = 4;
- hasUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The client does not need to set this.
- hasUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
-
The client does not need to set this.
- hasUser() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
-
The client does not need to set this.
- hasUser() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional string user = 6;
- hasUser() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
optional string user = 6;
- hasUser() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
optional string user = 6;
- hasUser() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional string user = 5;
- hasUser() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
optional string user = 5;
- hasUser() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
optional string user = 5;
- hasUser() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional string user = 6;
- hasUser() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
optional string user = 6;
- hasUser() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
optional string user = 6;
- hasUuid() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional string uuid = 3;
- hasUuid() - Method in class alluxio.grpc.CompleteFilePRequest
-
optional string uuid = 3;
- hasUuid() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
-
optional string uuid = 3;
- hasUuid() - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
uuid of its open file handle
- hasUuid() - Method in class alluxio.grpc.CreateFilePResponse
-
uuid of its open file handle
- hasUuid() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
-
uuid of its open file handle
- hasValue() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string value = 3;
- hasValue() - Method in class alluxio.grpc.ConfigProperty
-
optional string value = 3;
- hasValue() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
-
optional string value = 3;
- hasValue() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- hasValue() - Method in class alluxio.grpc.LocationBlockIdListEntry
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- hasValue() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- hasValue() - Method in class alluxio.grpc.Metric.Builder
-
optional double value = 4;
- hasValue() - Method in class alluxio.grpc.Metric
-
optional double value = 4;
- hasValue() - Method in interface alluxio.grpc.MetricOrBuilder
-
optional double value = 4;
- hasValue() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string value = 2;
- hasValue() - Method in class alluxio.proto.journal.File.StringPairEntry
-
optional string value = 2;
- hasValue() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
-
optional string value = 2;
- hasValue() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string value = 3;
- hasValue() - Method in class alluxio.proto.journal.Job.FileFilter
-
required string value = 3;
- hasValue() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
-
required string value = 3;
- hasVerbose() - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
optional bool verbose = 2;
- hasVerbose() - Method in class alluxio.grpc.JobProgressPOptions
-
optional bool verbose = 2;
- hasVerbose() - Method in interface alluxio.grpc.JobProgressPOptionsOrBuilder
-
optional bool verbose = 2;
- hasVerify() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool verify = 2;
- hasVerify() - Method in class alluxio.grpc.CopyJobPOptions
-
optional bool verify = 2;
- hasVerify() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional bool verify = 2;
- hasVerify() - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool verify = 2;
- hasVerify() - Method in class alluxio.grpc.LoadJobPOptions
-
optional bool verify = 2;
- hasVerify() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
-
optional bool verify = 2;
- hasVerify() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool verify = 2;
- hasVerify() - Method in class alluxio.grpc.MoveJobPOptions
-
optional bool verify = 2;
- hasVerify() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional bool verify = 2;
- hasVerify() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required bool verify = 5;
- hasVerify() - Method in class alluxio.proto.journal.Job.CopyJobEntry
-
required bool verify = 5;
- hasVerify() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
-
required bool verify = 5;
- hasVerify() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required bool verify = 4;
- hasVerify() - Method in class alluxio.proto.journal.Job.LoadJobEntry
-
required bool verify = 4;
- hasVerify() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
-
required bool verify = 4;
- hasVerify() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required bool verify = 5;
- hasVerify() - Method in class alluxio.proto.journal.Job.MoveJobEntry
-
required bool verify = 5;
- hasVerify() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
-
required bool verify = 5;
- hasVersion() - Method in class alluxio.grpc.BuildVersion.Builder
-
the project version
- hasVersion() - Method in class alluxio.grpc.BuildVersion
-
the project version
- hasVersion() - Method in interface alluxio.grpc.BuildVersionOrBuilder
-
the project version
- hasVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
optional int64 version = 1;
- hasVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse
-
optional int64 version = 1;
- hasVersion() - Method in interface alluxio.grpc.GetServiceVersionPResponseOrBuilder
-
optional int64 version = 1;
- hasVersion() - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- hasVersion() - Method in class alluxio.grpc.JobMasterStatus
-
optional .alluxio.grpc.BuildVersion version = 4;
- hasVersion() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 4;
- hasVersion() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional .alluxio.grpc.BuildVersion version = 8;
- hasVersion() - Method in class alluxio.grpc.JobWorkerHealth
-
optional .alluxio.grpc.BuildVersion version = 8;
- hasVersion() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 8;
- hasVersion() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string version = 7;
- hasVersion() - Method in class alluxio.grpc.MasterInfo
-
optional string version = 7;
- hasVersion() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional string version = 7;
- hasVersion() - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string version = 2;
- hasVersion() - Method in class alluxio.grpc.MasterVersion
-
optional string version = 2;
- hasVersion() - Method in interface alluxio.grpc.MasterVersionOrBuilder
-
optional string version = 2;
- hasVersion() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- hasVersion() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
-
optional .alluxio.grpc.BuildVersion version = 3;
- hasVersion() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 3;
- hasVersion() - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 5;
- hasVersion() - Method in class alluxio.grpc.ProxyStatus
-
optional .alluxio.grpc.BuildVersion version = 5;
- hasVersion() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 5;
- hasVersion() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- hasVersion() - Method in class alluxio.grpc.RegisterJobMasterPOptions
-
optional .alluxio.grpc.BuildVersion version = 4;
- hasVersion() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 4;
- hasVersion() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- hasVersion() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
optional .alluxio.grpc.BuildVersion version = 3;
- hasVersion() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
-
optional .alluxio.grpc.BuildVersion version = 3;
- hasVersion() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string version = 4;
- hasVersion() - Method in class alluxio.grpc.RegisterMasterPOptions
-
optional string version = 4;
- hasVersion() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
-
optional string version = 4;
- hasVersion() - Method in class alluxio.grpc.table.Partition.Builder
-
optional int64 version = 4;
- hasVersion() - Method in class alluxio.grpc.table.Partition
-
optional int64 version = 4;
- hasVersion() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
optional int64 version = 4;
- hasVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 version = 10;
- hasVersion() - Method in class alluxio.grpc.table.TableInfo
-
optional int64 version = 10;
- hasVersion() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional int64 version = 10;
- hasVersion() - Method in class alluxio.grpc.WorkerIdentity.Builder
-
version of the definition of the opaque identifier
- hasVersion() - Method in class alluxio.grpc.WorkerIdentity
-
version of the definition of the opaque identifier
- hasVersion() - Method in interface alluxio.grpc.WorkerIdentityOrBuilder
-
version of the definition of the opaque identifier
- hasVersionCreationTime() - Method in class alluxio.grpc.table.Partition.Builder
-
optional int64 version_creation_time = 5;
- hasVersionCreationTime() - Method in class alluxio.grpc.table.Partition
-
optional int64 version_creation_time = 5;
- hasVersionCreationTime() - Method in interface alluxio.grpc.table.PartitionOrBuilder
-
optional int64 version_creation_time = 5;
- hasVersionCreationTime() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 version_creation_time = 11;
- hasVersionCreationTime() - Method in class alluxio.grpc.table.TableInfo
-
optional int64 version_creation_time = 11;
- hasVersionCreationTime() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
-
optional int64 version_creation_time = 11;
- hasWebPort() - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int32 webPort = 8;
- hasWebPort() - Method in class alluxio.grpc.MasterInfo
-
optional int32 webPort = 8;
- hasWebPort() - Method in interface alluxio.grpc.MasterInfoOrBuilder
-
optional int32 webPort = 8;
- hasWebPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 webPort = 4;
- hasWebPort() - Method in class alluxio.grpc.WorkerNetAddress
-
optional int32 webPort = 4;
- hasWebPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional int32 webPort = 4;
- hasWhiteList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
optional bool white_list = 2;
- hasWhiteList() - Method in class alluxio.grpc.table.EquatableValueSet
-
optional bool white_list = 2;
- hasWhiteList() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
optional bool white_list = 2;
- hasWindowsDrive(String, boolean) - Static method in class alluxio.AlluxioURI
-
Checks if the path is a windows path.
- hasWorkerAddress() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- hasWorkerAddress() - Method in class alluxio.grpc.BlockLocation
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- hasWorkerAddress() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- hasWorkerHost() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string workerHost = 12;
- hasWorkerHost() - Method in class alluxio.grpc.JobInfo
-
optional string workerHost = 12;
- hasWorkerHost() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string workerHost = 12;
- hasWorkerHostname() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
required string workerHostname = 1;
- hasWorkerHostname() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
required string workerHostname = 1;
- hasWorkerHostname() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
-
required string workerHostname = 1;
- hasWorkerHostname() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
required string workerHostname = 1;
- hasWorkerHostname() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
required string workerHostname = 1;
- hasWorkerHostname() - Method in interface alluxio.grpc.RemoveDisabledWorkerPOptionsOrBuilder
-
required string workerHostname = 1;
- hasWorkerId() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the id of the worker
- hasWorkerId() - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the id of the worker
- hasWorkerId() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the id of the worker
- hasWorkerId() - Method in class alluxio.grpc.BlockLocation.Builder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.BlockLocation
-
optional int64 workerId = 1;
- hasWorkerId() - Method in interface alluxio.grpc.BlockLocationOrBuilder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the id of the worker
- hasWorkerId() - Method in class alluxio.grpc.CommitBlockPRequest
-
the id of the worker
- hasWorkerId() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
-
the id of the worker
- hasWorkerId() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
the id of the worker
- hasWorkerId() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
-
the id of the worker
- hasWorkerId() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
-
the id of the worker
- hasWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePRequest
-
optional int64 workerId = 1;
- hasWorkerId() - Method in interface alluxio.grpc.GetRegisterLeasePRequestOrBuilder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePResponse
-
optional int64 workerId = 1;
- hasWorkerId() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.GetWorkerIdPResponse
-
optional int64 workerId = 1;
- hasWorkerId() - Method in interface alluxio.grpc.GetWorkerIdPResponseOrBuilder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.JobWorkerHealth
-
optional int64 workerId = 1;
- hasWorkerId() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
optional int64 workerId = 1;
- hasWorkerId() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
-
optional int64 workerId = 1;
- hasWorkerId() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the id of the worker
- hasWorkerId() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the id of the worker
- hasWorkerId() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the id of the worker
- hasWorkerId() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional int64 worker_id = 1;
- hasWorkerId() - Method in class alluxio.proto.meta.Block.BlockLocation
-
optional int64 worker_id = 1;
- hasWorkerId() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
-
optional int64 worker_id = 1;
- hasWorkerLocation() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
If specified, the data will be written to the certain worker
- hasWorkerLocation() - Method in class alluxio.grpc.CreateFilePOptions
-
If specified, the data will be written to the certain worker
- hasWorkerLocation() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
If specified, the data will be written to the certain worker
- hasWorkerNetAddress() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
the worker network address
- hasWorkerNetAddress() - Method in class alluxio.grpc.GetWorkerIdPRequest
-
the worker network address
- hasWorkerNetAddress() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
-
the worker network address
- hasWorkerNetAddress() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
the worker network address
- hasWorkerNetAddress() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
-
the worker network address
- hasWorkerNetAddress() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
-
the worker network address
- hasWorkerNetAddress() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- hasWorkerNetAddress() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- hasWorkerNetAddress() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- hasWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
- hasWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions
-
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
- hasWorkerRange() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
-
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
- hasWorkerWebPort() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
optional int64 workerWebPort = 2;
- hasWorkerWebPort() - Method in class alluxio.grpc.DecommissionWorkerPOptions
-
optional int64 workerWebPort = 2;
- hasWorkerWebPort() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
-
optional int64 workerWebPort = 2;
- hasWorkerWebPort() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
optional int64 workerWebPort = 2;
- hasWorkerWebPort() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
-
optional int64 workerWebPort = 2;
- hasWorkerWebPort() - Method in interface alluxio.grpc.RemoveDisabledWorkerPOptionsOrBuilder
-
optional int64 workerWebPort = 2;
- hasWriteOptions() - Method in class alluxio.grpc.CopyRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- hasWriteOptions() - Method in class alluxio.grpc.CopyRequest
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- hasWriteOptions() - Method in interface alluxio.grpc.CopyRequestOrBuilder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- hasWriteOptions() - Method in class alluxio.grpc.MoveRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- hasWriteOptions() - Method in class alluxio.grpc.MoveRequest
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- hasWriteOptions() - Method in interface alluxio.grpc.MoveRequestOrBuilder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- hasWriteTier() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 writeTier = 7;
- hasWriteTier() - Method in class alluxio.grpc.CreateFilePOptions
-
optional int32 writeTier = 7;
- hasWriteTier() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional int32 writeTier = 7;
- hasWriteType() - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- hasWriteType() - Method in class alluxio.grpc.CopyJobPOptions
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- hasWriteType() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- hasWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
- hasWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
- hasWriteType() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
- hasWriteType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
- hasWriteType() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
- hasWriteType() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
- hasWriteType() - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- hasWriteType() - Method in class alluxio.grpc.MoveJobPOptions
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- hasWriteType() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- hasWriteType() - Method in class alluxio.grpc.WriteOptions.Builder
-
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
- hasWriteType() - Method in class alluxio.grpc.WriteOptions
-
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
- hasWriteType() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
-
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
- hasXattrPropStrat() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
- hasXattrPropStrat() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
- hasXattrPropStrat() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
- hasXattrPropStrat() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
- hasXattrPropStrat() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
- hasXattrPropStrat() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
- hasXattrUpdateStrategy() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
- hasXattrUpdateStrategy() - Method in class alluxio.grpc.SetAttributePOptions
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
- hasXattrUpdateStrategy() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
- hasXAttrUpdateStrategy() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
- hasXAttrUpdateStrategy() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
- hasXAttrUpdateStrategy() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
- HDFS - Class in alluxio.examples
-
Example program to use HDFS API to read and write files.
- HDFS() - Constructor for class alluxio.examples.HDFS
-
- HDFS_ACL_PROVIDER_CLASS - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
Name of the class for the HDFS Acl provider.
- HDFS_EC_CODEC_REGISTRY_CLASS - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
Name of the class for the HDFS EC Codec Registry.
- HDFS_EC_MIN_VERSION - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
The minimum HDFS production version required for EC.
- HDFS_TOOL_TYPE - Static variable in class alluxio.cli.ValidationConfig
-
- HDFS_USER - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- HdfsAclProvider - Interface in alluxio.underfs.hdfs
-
Interface for providing HDFS ACLs.
- HdfsConfParityValidationTask - Class in alluxio.cli.hdfs
-
Compares HDFS configuration in Alluxio and in HDFS environment variables.
- HdfsConfParityValidationTask(String, AlluxioConfiguration) - Constructor for class alluxio.cli.hdfs.HdfsConfParityValidationTask
-
Constructor.
- HdfsConfValidationTask - Class in alluxio.cli.hdfs
-
Class for validating HDFS-related configurations.
- HdfsConfValidationTask(String, AlluxioConfiguration) - Constructor for class alluxio.cli.hdfs.HdfsConfValidationTask
-
- HdfsFileInputStream - Class in alluxio.hadoop
-
HdfsFileInputStream implement for hadoop 1 and hadoop 2.
- HdfsFileInputStream(FileSystem, AlluxioURI, FileSystem.Statistics) - Constructor for class alluxio.hadoop.HdfsFileInputStream
-
Constructs a new stream for reading a file from HDFS.
- HdfsFileInputStream(FileInStream, FileSystem.Statistics) - Constructor for class alluxio.hadoop.HdfsFileInputStream
-
Constructs a new stream for reading a file from HDFS.
- HdfsPositionedUnderFileInputStream - Class in alluxio.underfs.hdfs
-
The input stream of HDFS as under filesystem.
- HdfsProxyUserValidationTask - Class in alluxio.cli.hdfs
-
Validates the proxyuser configurations for alluxio in hdfs.
- HdfsProxyUserValidationTask(String, AlluxioConfiguration) - Constructor for class alluxio.cli.hdfs.HdfsProxyUserValidationTask
-
- HdfsUnderFileInputStream - Class in alluxio.underfs.hdfs
-
The input stream of HDFS as under filesystem.
- HdfsUnderFileOutputStream - Class in alluxio.underfs.hdfs
-
- HdfsUnderFileOutputStream(FileSystem, String, FSDataOutputStream) - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
-
Basic constructor.
- HdfsUnderFileSystem - Class in alluxio.underfs.hdfs
-
- HdfsUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- HdfsUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration, boolean) - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- HdfsUnderFileSystemFactory - Class in alluxio.underfs.hdfs
-
- HdfsUnderFileSystemFactory() - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
-
- HdfsValidationTool - Class in alluxio.cli
-
A tool to validate an HDFS mount, before the path is mounted to Alluxio.
- HdfsValidationTool(String, UnderFileSystemConfiguration) - Constructor for class alluxio.cli.HdfsValidationTool
-
The constructor.
- HdfsValidationToolFactory - Class in alluxio.cli
-
Factory to create an HDFS validation tool implementation.
- HdfsValidationToolFactory() - Constructor for class alluxio.cli.HdfsValidationToolFactory
-
- HdfsVersion - Enum in alluxio.underfs.hdfs
-
The set of supported Hdfs versions.
- HdfsVersionValidationTask - Class in alluxio.cli.hdfs
-
Validates if the HDFS version works with the UFS version specified in
alluxio configuration.
- HdfsVersionValidationTask(AlluxioConfiguration) - Constructor for class alluxio.cli.hdfs.HdfsVersionValidationTask
-
- HdfsWorker(int, int, int, ByteBuffer, boolean, String) - Constructor for class alluxio.examples.Performance.HdfsWorker
-
- head(String, Integer) - Static method in class alluxio.util.network.HttpUtils
-
Uses the head method to send a url with arguments by http, this method can call RESTful Api.
- headBucket(String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
-
HeadBucket - head a bucket to check for existence.
- HeadCommand - Class in alluxio.cli.fs.command
-
Prints the file's first n bytes (by default, 1KB) to the console.
- HeadCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.HeadCommand
-
- HEADER - Static variable in class alluxio.Constants
-
- HEADER_ABFS - Static variable in class alluxio.Constants
-
- HEADER_ABFSS - Static variable in class alluxio.Constants
-
- HEADER_ADL - Static variable in class alluxio.Constants
-
- HEADER_ADLS - Static variable in class alluxio.Constants
-
- HEADER_CEPHFS - Static variable in class alluxio.Constants
-
- HEADER_CEPHFS_HADOOP - Static variable in class alluxio.Constants
-
- HEADER_CHARSET - Static variable in class alluxio.s3.S3Constants
-
- HEADER_COS - Static variable in class alluxio.Constants
-
- HEADER_COSN - Static variable in class alluxio.Constants
-
- HEADER_GCS - Static variable in class alluxio.Constants
-
- HEADER_OBS - Static variable in class alluxio.Constants
-
- HEADER_OSS - Static variable in class alluxio.Constants
-
- HEADER_S3 - Static variable in class alluxio.Constants
-
- HEADER_S3A - Static variable in class alluxio.Constants
-
- HEADER_WASB - Static variable in class alluxio.Constants
-
- HEADER_WASBS - Static variable in class alluxio.Constants
-
- HealthCheckClient - Interface in alluxio
-
Client for checking service availability.
- HeapBlockMetaStore - Class in alluxio.master.metastore.heap
-
This class requires external synchronization for operations on the same block id.
- HeapBlockMetaStore() - Constructor for class alluxio.master.metastore.heap.HeapBlockMetaStore
-
constructor a HeapBlockStore.
- HeapInodeStore - Class in alluxio.master.metastore.heap
-
FileStore implementation using on-heap data structures.
- HeapInodeStore() - Constructor for class alluxio.master.metastore.heap.HeapInodeStore
-
Construct a heap inode store.
- heartbeat(long) - Method in class alluxio.client.file.ConfigHashSync
-
- heartbeat() - Method in class alluxio.client.metrics.ClientMasterSync
-
Sends metrics to the master keyed with appId and client hostname.
- heartbeat(List<ClientMetrics>) - Method in interface alluxio.client.metrics.MetricsMasterClient
-
The method the worker should periodically execute to heartbeat back to the master.
- heartbeat(List<ClientMetrics>) - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
-
- heartbeat(long) - Method in class alluxio.fuse.meta.UpdateChecker
-
Heartbeat for the periodic update check.
- heartbeat(JobHeartbeatPRequest, StreamObserver<JobHeartbeatPResponse>) - Method in interface alluxio.grpc.JobMasterWorkerServiceGrpc.AsyncService
-
Periodic worker heartbeat returns a list of commands for the worker to execute.
- heartbeat(JobHeartbeatPRequest) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceBlockingStub
-
Periodic worker heartbeat returns a list of commands for the worker to execute.
- heartbeat(JobHeartbeatPRequest) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceFutureStub
-
Periodic worker heartbeat returns a list of commands for the worker to execute.
- heartbeat(JobHeartbeatPRequest, StreamObserver<JobHeartbeatPResponse>) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceStub
-
Periodic worker heartbeat returns a list of commands for the worker to execute.
- heartbeat(long) - Method in interface alluxio.heartbeat.HeartbeatExecutor
-
Implements the heartbeat logic.
- heartbeat(long) - Method in class alluxio.master.block.DefaultBlockMaster.LostWorkerDetectionHeartbeatExecutor
-
- heartbeat(long) - Method in class alluxio.master.block.DefaultBlockMaster.WorkerRegisterStreamGCExecutor
-
- heartbeat(JobHeartbeatPRequest, StreamObserver<JobHeartbeatPResponse>) - Method in class alluxio.master.job.JobMasterWorkerServiceHandler
-
- heartbeat(long) - Method in class alluxio.master.meta.JobMasterSync
-
Heartbeats to the leader master node.
- heartbeat(long) - Method in class alluxio.master.meta.JournalSpaceMonitor
-
- heartbeat(long) - Method in class alluxio.master.meta.MetaMasterSync
-
Heartbeats to the leader master node.
- heartbeat(long) - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
-
Sends a heartbeat to the leader master.
- heartbeat(long) - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
-
Sends a heartbeat to the leader master.
- heartbeat(long) - Method in class alluxio.master.meta.UpdateChecker
-
Heartbeat for the periodic update check.
- heartbeat(long) - Method in class alluxio.proxy.ProxyMasterSync
-
Heartbeats to the primary master node.
- heartbeat() - Method in class alluxio.SessionInfo
-
Performs a session heartbeat.
- heartbeat(long, Map<String, Long>, Map<String, Long>, List<Long>, Map<BlockStoreLocation, List<Long>>, Map<String, List<String>>, List<Metric>) - Method in class alluxio.worker.block.BlockMasterClient
-
The method the worker should periodically execute to heartbeat back to the master.
- heartbeat(long) - Method in class alluxio.worker.job.command.CommandHandlingExecutor
-
- heartbeat(JobWorkerHealth, List<JobInfo>) - Method in interface alluxio.worker.job.JobMasterClient
-
Periodic heartbeats to update the tasks' status from a worker, and returns the commands.
- heartbeat(JobWorkerHealth, List<JobInfo>) - Method in class alluxio.worker.job.RetryHandlingJobMasterClient
-
- HeartbeatContext - Class in alluxio.heartbeat
-
This is a static class for storing and retrieving heartbeat related information.
- HeartbeatContext.HeartbeatType - Enum in alluxio.heartbeat
-
HeartBeat Enum Type.
- HeartbeatExecutor - Interface in alluxio.heartbeat
-
An interface for a heartbeat execution.
- HeartbeatHandler - Class in alluxio.worker.netty
-
A handler for heartbeat events.
- HeartbeatHandler() - Constructor for class alluxio.worker.netty.HeartbeatHandler
-
Constructs a new heartbeat handler.
- HeartbeatScheduler - Class in alluxio.heartbeat
-
This class can be used for controlling heartbeat execution of a thread.
- HeartbeatThread - Class in alluxio.heartbeat
-
Thread class to execute a heartbeat periodically.
- HeartbeatThread(String, String, HeartbeatExecutor, Supplier<SleepIntervalSupplier>, AlluxioConfiguration, UserState, Clock) - Constructor for class alluxio.heartbeat.HeartbeatThread
-
- HeartbeatThread(String, HeartbeatExecutor, Supplier<SleepIntervalSupplier>, AlluxioConfiguration, UserState) - Constructor for class alluxio.heartbeat.HeartbeatThread
-
- HeartbeatThread(String, HeartbeatExecutor, Supplier<SleepIntervalSupplier>, AlluxioConfiguration, UserState, Clock) - Constructor for class alluxio.heartbeat.HeartbeatThread
-
- HeartbeatThread.Status - Enum in alluxio.heartbeat
-
Enum representing the status of HeartbeatThread.
- HeartbeatTimer - Interface in alluxio.heartbeat
-
An interface for heartbeat timers.
- HELP_FLAG - Static variable in class alluxio.stress.BaseParameters
-
- HELP_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.DoctorCommand
-
- HELP_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
-
- HelpCommand - Class in alluxio.cli.fs.command
-
Command for print help message for the given command.
- HelpCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.HelpCommand
-
- helpComplete(int) - Method in class alluxio.concurrent.jsr.CountedCompleter
-
If this task has not completed, attempts to process at most the given number of other
unprocessed tasks for which this task is on the completion path, if any are known to exist.
- helpQuiesce() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
-
Possibly executes tasks until the pool hosting the current task
is quiescent.
- HFSUtils - Class in alluxio.util
-
Utility method called in alluxio-mount.sh to calculate space for Mac OS X HFS+.
- HIGH_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Range
-
- HIGH_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DateColumnStatsData
-
- HIGH_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DecimalColumnStatsData
-
- HIGH_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DoubleColumnStatsData
-
- HIGH_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.LongColumnStatsData
-
- histogram(String) - Static method in class alluxio.metrics.MetricsSystem
-
Get or add a histogram with the given name.
- HISTOGRAM_VALUE - Static variable in enum alluxio.grpc.MetricType
-
HISTOGRAM gives statistics about the value of past occurrences of an event.
- HiveBucketProperty - Class in alluxio.grpc.table.layout.hive
-
Protobuf type alluxio.grpc.table.layout.HiveBucketProperty
- HiveBucketProperty.Builder - Class in alluxio.grpc.table.layout.hive
-
Protobuf type alluxio.grpc.table.layout.HiveBucketProperty
- HiveBucketPropertyOrBuilder - Interface in alluxio.grpc.table.layout.hive
-
- HiveCacheContext - Class in alluxio.client.hive
-
Data structure that stores and returns Hive related Cache Scope.
- HiveCacheContext(String, String, String) - Constructor for class alluxio.client.hive.HiveCacheContext
-
Constructor.
- HiveLayoutProto - Class in alluxio.grpc.table.layout.hive
-
- HMS_TOOL_TYPE - Static variable in class alluxio.cli.ValidationConfig
-
- HmsValidationTool - Class in alluxio.cli
-
Run tests against an existing hive metastore.
- HmsValidationToolFactory - Class in alluxio.cli
-
Factory to create hive metastore validation tool implementation.
- HmsValidationToolFactory() - Constructor for class alluxio.cli.HmsValidationToolFactory
-
- HOME - Static variable in class alluxio.conf.PropertyKey
-
- HOME - Static variable in class alluxio.conf.PropertyKey.Name
-
- HOST_FIELD_NUMBER - Static variable in class alluxio.grpc.NetAddress
-
- HOST_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerNetAddress
-
- HOSTNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
-
- HOUR - Static variable in class alluxio.Constants
-
- HOUR_MS - Static variable in class alluxio.Constants
-
- HTTP_VERSION - Static variable in class alluxio.s3.NettyRestUtils
-
- HttpFilter - Class in alluxio.web
-
Provides an abstract class to be subclassed to create an HTTP filter.
- HttpFilter() - Constructor for class alluxio.web.HttpFilter
-
- HttpRequestUri - Class in alluxio.worker.http
-
A wrapped DO of the HTTP request URI.
- HttpRequestUtil - Class in alluxio.worker.http
-
Util class for handling HTTP request.
- HttpRequestUtil() - Constructor for class alluxio.worker.http.HttpRequestUtil
-
- HttpResponseContext - Class in alluxio.worker.http
-
Http response context for wrapping useful information.
- HttpResponseContext(HttpResponse, FileRegion) - Constructor for class alluxio.worker.http.HttpResponseContext
-
Http response context for wrapping useful information.
- HttpServer - Class in alluxio.worker.http
-
- HttpServer(HttpServerInitializer) - Constructor for class alluxio.worker.http.HttpServer
-
- HttpServerHandler - Class in alluxio.worker.http
-
- HttpServerHandler(PagedService) - Constructor for class alluxio.worker.http.HttpServerHandler
-
- HttpServerInitializer - Class in alluxio.worker.http
-
- HttpServerInitializer(PagedService) - Constructor for class alluxio.worker.http.HttpServerInitializer
-
- HttpUtils - Class in alluxio.util.network
-
Utility methods for working with http.
- HttpUtils.IProcessInputStream - Interface in alluxio.util.network
-
This interface should be implemented by the http response body stream processor.
- S3_ACCEPT_RANGES_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_ACCEPT_RANGES_VALUE - Static variable in class alluxio.s3.S3Constants
-
- S3_ACL_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_CONTENT_LENGTH_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_CONTENT_RANGE_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_CONTENT_TYPE_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_COPY_SOURCE_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_COPY_SOURCE_RANGE - Static variable in class alluxio.s3.S3Constants
-
- S3_COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
-
Cost map is a map between ufs operations and their associated cost in dollars per operation.
- S3_DATE_FORMAT_REGEXP - Static variable in class alluxio.s3.S3Constants
-
- S3_DELETE_IN_ALLUXIO_AND_UFS - Static variable in class alluxio.Constants
-
- S3_DELETE_IN_ALLUXIO_ONLY - Static variable in class alluxio.Constants
-
- S3_ETAG_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_HANDLER_ATTRIBUTE - Static variable in class alluxio.web.ProxyWebServer
-
- S3_METADATA_DIRECTIVE_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_METADATA_ROOT_DIR - Static variable in class alluxio.s3.S3Constants
-
- S3_METADATA_UPLOADS_DIR - Static variable in class alluxio.s3.S3Constants
-
- S3_MULTIPART_PART_PREFIX - Static variable in class alluxio.s3.S3Constants
-
- S3_REST_AUTHENTICATION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- S3_REST_AUTHENTICATION_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- S3_REST_AUTHENTICATOR_CLASSNAME - Static variable in class alluxio.conf.PropertyKey.Name
-
- S3_REST_AUTHENTICATOR_CLASSNAME - Static variable in class alluxio.conf.PropertyKey
-
- S3_SIGN_ALGORITHM - Static variable in class alluxio.s3.S3Constants
-
- S3_SIGN_CONTENT_SHA256 - Static variable in class alluxio.s3.S3Constants
-
- S3_SIGN_CREDENTIAL - Static variable in class alluxio.s3.S3Constants
-
- S3_SIGN_DATE - Static variable in class alluxio.s3.S3Constants
-
- S3_SIGN_EXPIRES - Static variable in class alluxio.s3.S3Constants
-
- S3_SIGN_SIGNATURE - Static variable in class alluxio.s3.S3Constants
-
- S3_SIGN_SIGNED_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_STANDARD_STORAGE_CLASS - Static variable in class alluxio.s3.S3Constants
-
- S3_TAGGING_COUNT_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_TAGGING_DIRECTIVE_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_TAGGING_HEADER - Static variable in class alluxio.s3.S3Constants
-
- S3_UPLOADS_ID_XATTR_KEY - Static variable in class alluxio.conf.PropertyKey.Name
-
- S3_V2_SERVICE_PATH_PREFIX - Static variable in class alluxio.proxy.s3.S3RequestServlet
-
- S3_WRITE_TYPE - Static variable in class alluxio.worker.s3.S3NettyHandler
-
- S3A_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
-
- S3A_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
-
- S3A_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
-
- S3A_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
-
- S3AInputStream - Class in alluxio.underfs.s3a
-
An S3A input stream that supports skip and seek efficiently.
- S3AInputStream(String, String, AmazonS3, long, RetryPolicy) - Constructor for class alluxio.underfs.s3a.S3AInputStream
-
Constructor for an input stream of an object in s3 using the aws-sdk implementation to read the
data.
- S3ALowLevelOutputStream - Class in alluxio.underfs.s3a
-
Object storage low output stream for aws s3.
- S3ALowLevelOutputStream(String, String, AmazonS3, ListeningExecutorService, AlluxioConfiguration) - Constructor for class alluxio.underfs.s3a.S3ALowLevelOutputStream
-
Constructs a new stream for writing a file.
- S3AMultipartUploadOutputStream - Class in alluxio.underfs.s3a
-
Object storage multipart upload for aws s3.
- S3AMultipartUploadOutputStream(String, String, AmazonS3, ListeningExecutorService, AlluxioConfiguration) - Constructor for class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
-
Constructs a new stream for writing a file.
- S3AOutputStream - Class in alluxio.underfs.s3a
-
A stream for writing a file into S3.
- S3AOutputStream(String, String, TransferManager, List<String>, boolean) - Constructor for class alluxio.underfs.s3a.S3AOutputStream
-
Constructs a new stream for writing a file.
- S3APositionReader - Class in alluxio.underfs.s3a
-
- S3APositionReader(AmazonS3, String, String, long) - Constructor for class alluxio.underfs.s3a.S3APositionReader
-
- S3ASpecificOperations - Class in alluxio.cli
-
Examples for S3A specific under filesystem operations.
- S3ASpecificOperations(String, UnderFileSystem, InstancedConfiguration) - Constructor for class alluxio.cli.S3ASpecificOperations
-
- S3AuditContext - Class in alluxio.s3
-
An audit context for s3 rest service.
- S3AuditContext(AsyncUserAccessAuditLogWriter) - Constructor for class alluxio.s3.S3AuditContext
-
- S3AUnderFileSystem - Class in alluxio.underfs.s3a
-
- S3AUnderFileSystem(AlluxioURI, AmazonS3, S3AsyncClient, String, ExecutorService, TransferManager, UnderFileSystemConfiguration, boolean, boolean) - Constructor for class alluxio.underfs.s3a.S3AUnderFileSystem
-
- S3AUnderFileSystem.S3AObjectListingChunk - Class in alluxio.underfs.s3a
-
Wrapper over S3 ListObjectsV2Request
.
- S3AUnderFileSystem.S3AObjectListingChunkV1 - Class in alluxio.underfs.s3a
-
Wrapper over S3 ListObjectsRequest
.
- S3AUnderFileSystemFactory - Class in alluxio.underfs.s3a
-
- S3AUnderFileSystemFactory() - Constructor for class alluxio.underfs.s3a.S3AUnderFileSystemFactory
-
- S3AuthenticationFilter - Class in alluxio.proxy.s3
-
Authentication filter for S3 API.
- S3AuthenticationFilter() - Constructor for class alluxio.proxy.s3.S3AuthenticationFilter
-
- S3AUtils - Class in alluxio.underfs.s3a
-
Util functions for S3A under file system.
- S3BaseTask - Class in alluxio.proxy.s3
-
S3 Abstract Base task for handling S3 API logic.
- S3BaseTask(S3Handler, S3BaseTask.OpType) - Constructor for class alluxio.proxy.s3.S3BaseTask
-
Instantiate a S3BaseTask.
- S3BaseTask.OpTag - Enum in alluxio.proxy.s3
-
Enum for tagging the http request to target for
different threadpools for handling.
- S3BaseTask.OpType - Enum in alluxio.proxy.s3
-
Enum indicating name of S3 API handling per http request.
- S3BucketTask - Class in alluxio.proxy.s3
-
S3 Tasks to handle bucket level or global level request.
- S3BucketTask(S3Handler, S3BaseTask.OpType) - Constructor for class alluxio.proxy.s3.S3BucketTask
-
- S3BucketTask.Factory - Class in alluxio.proxy.s3
-
Factory for getting a S3BucketTask type task.
- S3Constants - Class in alluxio.s3
-
Constants for S3 northbound API.
- S3Constants.Directive - Enum in alluxio.s3
-
Directive specifies whether metadata/tag-set are copied from the source object
or replaced with metadata/tag-set provided in the request.
- S3Error - Class in alluxio.s3
-
Error response defined in http://docs.aws.amazon.com/AmazonS3/latest/API/ErrorResponses.html.
- S3Error() - Constructor for class alluxio.s3.S3Error
-
- S3Error(String, S3ErrorCode) - Constructor for class alluxio.s3.S3Error
-
- S3ErrorCode - Class in alluxio.s3
-
Error codes defined in http://docs.aws.amazon.com/AmazonS3/latest/API/ErrorResponses.html with
API version 2006-03-01.
- S3ErrorCode(String, String, Response.Status) - Constructor for class alluxio.s3.S3ErrorCode
-
- S3ErrorCode.Name - Class in alluxio.s3
-
- S3ErrorResponse - Class in alluxio.s3
-
Utilities for creating HTTP Responses for the S3 API.
- S3ErrorResponse() - Constructor for class alluxio.s3.S3ErrorResponse
-
- S3Exception - Exception in alluxio.s3
-
An exception thrown during processing S3 REST requests.
- S3Exception(S3ErrorCode) - Constructor for exception alluxio.s3.S3Exception
-
- S3Exception(String, S3ErrorCode) - Constructor for exception alluxio.s3.S3Exception
-
- S3Exception(Exception, String, S3ErrorCode) - Constructor for exception alluxio.s3.S3Exception
-
- S3Exception(String, String, S3ErrorCode) - Constructor for exception alluxio.s3.S3Exception
-
- S3Handler - Class in alluxio.proxy.s3
-
- S3Handler(String, String, HttpServletRequest, HttpServletResponse) - Constructor for class alluxio.proxy.s3.S3Handler
-
S3Handler Constructor.
- S3HttpHandler - Class in alluxio.worker.s3
-
Handles S3 HTTP request.
- S3HttpHandler(FileSystem, DoraWorker, AsyncUserAccessAuditLogWriter, ThreadPoolExecutor, ThreadPoolExecutor) - Constructor for class alluxio.worker.s3.S3HttpHandler
-
- S3HttpPipelineHandler - Class in alluxio.worker.s3
-
Adds the http server's pipeline into the channel.
- S3HttpPipelineHandler(FileSystem, DoraWorker) - Constructor for class alluxio.worker.s3.S3HttpPipelineHandler
-
- S3NettyBaseTask - Class in alluxio.worker.s3
-
S3 Abstract Base task for handling S3 API logic in netty server.
- S3NettyBaseTask(S3NettyHandler, S3NettyBaseTask.OpType) - Constructor for class alluxio.worker.s3.S3NettyBaseTask
-
- S3NettyBaseTask.OpTag - Enum in alluxio.worker.s3
-
Enum for tagging the http request to target for
different threadpools for handling.
- S3NettyBaseTask.OpType - Enum in alluxio.worker.s3
-
Enum indicating name of S3 API handling per http request.
- S3NettyBucketTask - Class in alluxio.worker.s3
-
S3 Netty Tasks to handle bucket level or global level request.
- S3NettyBucketTask(S3NettyHandler, S3NettyBaseTask.OpType) - Constructor for class alluxio.worker.s3.S3NettyBucketTask
-
- S3NettyBucketTask.Factory - Class in alluxio.worker.s3
-
Factory for getting a S3BucketTask type task.
- S3NettyHandler - Class in alluxio.worker.s3
-
S3 Netty Handler - handle http requests from S3 API in Netty.
- S3NettyHandler(String, String, HttpRequest, ChannelHandlerContext, FileSystem, DoraWorker, AsyncUserAccessAuditLogWriter) - Constructor for class alluxio.worker.s3.S3NettyHandler
-
- S3NettyObjectTask - Class in alluxio.worker.s3
-
S3 Netty Tasks to handle object level request.
- S3NettyObjectTask(S3NettyHandler, S3NettyBaseTask.OpType) - Constructor for class alluxio.worker.s3.S3NettyObjectTask
-
- S3NettyObjectTask.Factory - Class in alluxio.worker.s3
-
Factory for getting a S3ObjectTask.
- S3ObjectTask - Class in alluxio.proxy.s3
-
S3 Tasks to handle object level request.
- S3ObjectTask(S3Handler, S3BaseTask.OpType) - Constructor for class alluxio.proxy.s3.S3ObjectTask
-
- S3ObjectTask.CompleteMultipartUploadTask - Class in alluxio.proxy.s3
-
CompleteMultipartUploadTask.
- S3ObjectTask.Factory - Class in alluxio.proxy.s3
-
Factory for getting a S3ObjectTask.
- S3RangeSpec - Class in alluxio.s3
-
This class is Range Spec for Amazon S3 API.
- S3RangeSpec(boolean) - Constructor for class alluxio.s3.S3RangeSpec
-
- S3RangeSpec(long, long) - Constructor for class alluxio.s3.S3RangeSpec
-
- S3RangeSpec.Factory - Class in alluxio.s3
-
- S3RequestServlet - Class in alluxio.proxy.s3
-
New architecture Request Servlet for handling s3 requests
in replacement of JAX-RS.
- S3RequestServlet() - Constructor for class alluxio.proxy.s3.S3RequestServlet
-
- S3RestExceptionMapper - Class in alluxio.proxy.s3
-
An exception mapper for REST PROXY to convert inner exception to HTTP Response.
- S3RestExceptionMapper() - Constructor for class alluxio.proxy.s3.S3RestExceptionMapper
-
- S3RestServiceHandler - Class in alluxio.proxy.s3
-
This class is a REST handler for Amazon S3 API.
- S3RestServiceHandler(ServletContext) - Constructor for class alluxio.proxy.s3.S3RestServiceHandler
-
- S3RestUtils - Class in alluxio.proxy.s3
-
Utilities for handling S3 REST calls.
- S3RestUtils.RestCallable<T> - Interface in alluxio.proxy.s3
-
An interface representing a callable.
- S3RestUtils.URIStatusNameComparator - Class in alluxio.proxy.s3
-
Comparator based on uri name, treat uri name as a Long number.
- S3SyntaxOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.S3SyntaxOptions
- S3SyntaxOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.S3SyntaxOptions
- S3SYNTAXOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePOptions
-
- S3SyntaxOptionsOrBuilder - Interface in alluxio.grpc
-
- S_CLIENT_ID_KEY - Static variable in class alluxio.security.authentication.ChannelIdInjector
-
Metadata key for the channel Id.
- S_CLIENT_VERSION_KEY - Static variable in class alluxio.grpc.ClientVersionClientInjector
-
- SAFE_MODE_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
-
SAFE_MODE = 3;
- safeManagedBlock(ForkJoinPool.ManagedBlocker) - Static method in class alluxio.concurrent.ForkJoinPoolHelper
-
Does managed blocking on ForkJoinPool.
- SAFEMODE_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
-
- SafeModeManager - Interface in alluxio.master
-
Interface for managing safe mode state.
- SafeUfsDeleter - Class in alluxio.master.file
-
Helper class for deleting persisted entries from the UFS.
- SafeUfsDeleter(MountTable, ReadOnlyInodeStore, List<Pair<AlluxioURI, LockedInodePath>>, DeletePOptions) - Constructor for class alluxio.master.file.SafeUfsDeleter
-
- SamplingLogger - Class in alluxio.util.logging
-
A logger which limits log message frequency to prevent spamming the logs.
- SamplingLogger(Logger, long) - Constructor for class alluxio.util.logging.SamplingLogger
-
- SaslAuthenticationServiceGrpc - Class in alluxio.grpc
-
- SaslAuthenticationServiceGrpc.AsyncService - Interface in alluxio.grpc
-
- SaslAuthenticationServiceGrpc.SaslAuthenticationServiceBlockingStub - Class in alluxio.grpc
-
A stub to allow clients to do synchronous rpc calls to service SaslAuthenticationService.
- SaslAuthenticationServiceGrpc.SaslAuthenticationServiceFutureStub - Class in alluxio.grpc
-
A stub to allow clients to do ListenableFuture-style rpc calls to service SaslAuthenticationService.
- SaslAuthenticationServiceGrpc.SaslAuthenticationServiceImplBase - Class in alluxio.grpc
-
Base class for the server implementation of the service SaslAuthenticationService.
- SaslAuthenticationServiceGrpc.SaslAuthenticationServiceStub - Class in alluxio.grpc
-
A stub to allow clients to do asynchronous rpc calls to service SaslAuthenticationService.
- SaslAuthenticationServiceImplBase() - Constructor for class alluxio.grpc.SaslAuthenticationServiceGrpc.SaslAuthenticationServiceImplBase
-
- SaslClientHandler - Interface in alluxio.security.authentication
-
Interface for authentication scheme specific
SaslClient
management.
- SaslClientHandlerPlain - Class in alluxio.security.authentication.plain
-
- SaslClientHandlerPlain(Subject, AlluxioConfiguration) - Constructor for class alluxio.security.authentication.plain.SaslClientHandlerPlain
-
- SaslClientHandlerPlain(String, String, String) - Constructor for class alluxio.security.authentication.plain.SaslClientHandlerPlain
-
- SaslMessage - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.sasl.SaslMessage
- SaslMessage.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.sasl.SaslMessage
- SaslMessageOrBuilder - Interface in alluxio.grpc
-
- SaslMessageType - Enum in alluxio.grpc
-
Protobuf enum alluxio.grpc.sasl.SaslMessageType
- SaslServerHandler - Interface in alluxio.security.authentication
-
Interface for authentication scheme specific
SaslServer
management.
- SaslServerHandlerPlain - Class in alluxio.security.authentication.plain
-
- SaslServerHandlerPlain(String, AlluxioConfiguration, ImpersonationAuthenticator) - Constructor for class alluxio.security.authentication.plain.SaslServerHandlerPlain
-
- saveWorkdir() - Method in class alluxio.multi.process.MultiProcessCluster
-
Copies the work directory to the artifacts folder.
- sCachedGroupMapping - Static variable in class alluxio.security.group.GroupMappingService.Factory
-
- SCALE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Decimal
-
- SCANCOMPLETED_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
-
- scanPages(Consumer<Optional<PageInfo>>) - Method in class alluxio.client.file.cache.store.LocalPageStoreDir
-
Gets a stream of all pages from the page store.
- scanPages(Consumer<Optional<PageInfo>>) - Method in class alluxio.client.file.cache.store.MemoryPageStoreDir
-
- scanPages(Consumer<Optional<PageInfo>>) - Method in interface alluxio.client.file.cache.store.PageStoreDir
-
Scan the pages under this dir.
- SCANPENDINGACTION_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
-
- scanRegistered(String, S) - Method in class alluxio.extensions.ExtensionFactoryRegistry
-
Finds factories from registered collection.
- SCANSTARTEDMS_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
-
- SCANTOTAL_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
-
- schedule(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
-
Schedules execution of a heartbeat for the given thread.
- schedule() - Method in class alluxio.heartbeat.ScheduledTimer
-
Schedules execution of the heartbeat.
- schedule(Duration, Runnable) - Method in class alluxio.master.transport.GrpcMessagingContext
-
Submits a one-shot task that becomes enabled after the given delay.
- schedule(Duration, Duration, Runnable) - Method in class alluxio.master.transport.GrpcMessagingContext
-
Submits a one-shot task that becomes enabled after the given delay.
- schedule(Runnable, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
-
- schedule(Callable<V>, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
-
- scheduleAsyncPersist(AlluxioURI, ScheduleAsyncPersistencePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Schedules the async persistence of the given file.
- scheduleAsyncPersist(AlluxioURI, ScheduleAsyncPersistencePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- scheduleAsyncPersistDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- scheduleAsyncPersistence(ScheduleAsyncPersistencePRequest, StreamObserver<ScheduleAsyncPersistencePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Schedules async persistence.
- scheduleAsyncPersistence(ScheduleAsyncPersistencePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Schedules async persistence.
- scheduleAsyncPersistence(ScheduleAsyncPersistencePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Schedules async persistence.
- scheduleAsyncPersistence(ScheduleAsyncPersistencePRequest, StreamObserver<ScheduleAsyncPersistencePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Schedules async persistence.
- scheduleAsyncPersistence(AlluxioURI) - Method in interface alluxio.master.file.async.AsyncPersistHandler
-
Schedules a file for async persistence.
- scheduleAsyncPersistence(AlluxioURI) - Method in class alluxio.master.file.async.DefaultAsyncPersistHandler
-
- scheduleAsyncPersistence(AlluxioURI, ScheduleAsyncPersistenceContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- scheduleAsyncPersistence(AlluxioURI, ScheduleAsyncPersistenceContext) - Method in interface alluxio.master.file.FileSystemMaster
-
Schedules a file for async persistence.
- scheduleAsyncPersistence(ScheduleAsyncPersistencePRequest, StreamObserver<ScheduleAsyncPersistencePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- ScheduleAsyncPersistenceContext - Class in alluxio.master.file.contexts
-
- scheduleAsyncPersistenceDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- ScheduleAsyncPersistencePOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePOptions
- ScheduleAsyncPersistencePOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePOptions
- ScheduleAsyncPersistencePOptionsOrBuilder - Interface in alluxio.grpc
-
- ScheduleAsyncPersistencePRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePRequest
- ScheduleAsyncPersistencePRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePRequest
- ScheduleAsyncPersistencePRequestOrBuilder - Interface in alluxio.grpc
-
- ScheduleAsyncPersistencePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePResponse
- ScheduleAsyncPersistencePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePResponse
- ScheduleAsyncPersistencePResponseOrBuilder - Interface in alluxio.grpc
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
-
- SCHEDULED_TIMER_CLASS - Static variable in class alluxio.heartbeat.HeartbeatContext
-
- ScheduledTimer - Class in alluxio.heartbeat
-
This class can be used for controlling heartbeat execution of threads.
- ScheduledTimer(String, Clock, Supplier<SleepIntervalSupplier>) - Constructor for class alluxio.heartbeat.ScheduledTimer
-
- Scheduler - Class in alluxio.master.scheduler
-
The Scheduler which controls jobs.
- Scheduler(FileSystemContext, WorkerProvider, JobMetaStore) - Constructor for class alluxio.master.scheduler.Scheduler
-
Constructor.
- Scheduler.BoundedPriorityBlockingQueue<E> - Class in alluxio.master.scheduler
-
Bounded priority queue impl.
- Scheduler.SchedulerStats - Class in alluxio.master.scheduler
-
Job/Tasks stats.
- Scheduler.WorkerInfoHub - Class in alluxio.master.scheduler
-
Worker information hub.
- Scheduler.WorkerInfoIdentity - Class in alluxio.master.scheduler
-
Util class here for tracking unique identity of a worker as
WorkerInfo class uses constantly changing field such as
mLastContactSec for equals(), which can't be served as key
class in map.
- SCHEDULER_INFO - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
- scheduleRemoveFromWorker(long) - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
Remove the block from the worker metadata and add to the to-remove list.
- schedulerIsIdle() - Method in class alluxio.util.executor.ControllableScheduler
-
Reports whether scheduler has no commands/tasks pending immediate execution.
- SchedulerStats() - Constructor for class alluxio.master.scheduler.Scheduler.SchedulerStats
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
-
- Schema - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.Schema
- Schema.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.Schema
- SCHEMA_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
-
- SchemaOrBuilder - Interface in alluxio.grpc.table
-
- SCHEME - Static variable in class alluxio.Constants
-
- scope(CacheScope) - Static method in interface alluxio.client.file.cache.CacheUsage.PartitionDescriptor
-
Creates a partition of a cache scope.
- Scope - Enum in alluxio.grpc
-
Protobuf enum alluxio.grpc.meta.Scope
- Scoped - Interface in alluxio.util.interfaces
-
Extension of Closeable which throws no checked exceptions.
- ScopeEncoder - Class in alluxio.client.file.cache.cuckoofilter
-
A scope encoder that supports encode/decode scope information.
- ScopeEncoder(int) - Constructor for class alluxio.client.file.cache.cuckoofilter.ScopeEncoder
-
Create a scope encoder.
- ScopePartition(CacheScope) - Constructor for class alluxio.client.file.cache.CacheUsage.ScopePartition
-
Creates a partition over a cache scope.
- ScpCommand - Class in alluxio.shell
-
Object representation of a remote scp command.
- ScpCommand(String, String, String) - Constructor for class alluxio.shell.ScpCommand
-
Creates a remote scp command to copy a file to local.
- ScpCommand(String, String, String, boolean) - Constructor for class alluxio.shell.ScpCommand
-
Creates a remote scp command to copy a file/dir to local.
- scpCommandWithOutput(String, String, String, boolean) - Static method in class alluxio.util.ShellUtils
-
Static method to execute an scp command to copy a remote file/dir to local.
- sDoraCacheFileSystemFactory - Static variable in class alluxio.client.file.DoraCacheFileSystem
-
- SECOND - Static variable in class alluxio.Constants
-
- SECOND_MS - Static variable in class alluxio.Constants
-
- SECOND_NANO - Static variable in class alluxio.Constants
-
- SECOND_TIER - Static variable in class alluxio.Constants
-
- SecureHdfsValidationTask - Class in alluxio.cli.hdfs
-
Task for validating security configurations.
- SecureHdfsValidationTask(String, String, AlluxioConfiguration) - Constructor for class alluxio.cli.hdfs.SecureHdfsValidationTask
-
- SECURITY_AUTHENTICATION_CUSTOM_PROVIDER_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
-
- SECURITY_AUTHENTICATION_CUSTOM_PROVIDER_CLASS - Static variable in class alluxio.conf.PropertyKey
-
- SECURITY_AUTHENTICATION_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
-
- SECURITY_AUTHENTICATION_TYPE - Static variable in class alluxio.conf.PropertyKey
-
- SECURITY_AUTHORIZATION_PERMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- SECURITY_AUTHORIZATION_PERMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- SECURITY_AUTHORIZATION_PERMISSION_SUPERGROUP - Static variable in class alluxio.conf.PropertyKey.Name
-
- SECURITY_AUTHORIZATION_PERMISSION_SUPERGROUP - Static variable in class alluxio.conf.PropertyKey
-
- SECURITY_AUTHORIZATION_PERMISSION_UMASK - Static variable in class alluxio.conf.PropertyKey.Name
-
- SECURITY_AUTHORIZATION_PERMISSION_UMASK - Static variable in class alluxio.conf.PropertyKey
-
- SECURITY_GROUP_MAPPING_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
-
- SECURITY_GROUP_MAPPING_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
-
- SECURITY_GROUP_MAPPING_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
-
- SECURITY_GROUP_MAPPING_CLASS - Static variable in class alluxio.conf.PropertyKey
-
- SECURITY_LOGIN_IMPERSONATION_USERNAME - Static variable in class alluxio.conf.PropertyKey.Name
-
- SECURITY_LOGIN_IMPERSONATION_USERNAME - Static variable in class alluxio.conf.PropertyKey
-
- SECURITY_LOGIN_USERNAME - Static variable in class alluxio.conf.PropertyKey.Name
-
- SECURITY_LOGIN_USERNAME - Static variable in class alluxio.conf.PropertyKey
-
- SECURITY_SERVER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
-
SECURITY_SERVER_CLIENT_SERVICE = 1005;
- SECURITY_SERVER_VERSION - Static variable in class alluxio.Constants
-
- SecurityUtils - Class in alluxio.jnifuse.utils
-
- SecurityUtils - Class in alluxio.util
-
Utility methods for security.
- seek(long) - Method in class alluxio.client.block.stream.SharedGrpcDataReader
-
Seeks to a specific position.
- seek(long) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
-
- seek(long) - Method in class alluxio.client.file.PositionReadFileInStream
-
- seek(long) - Method in class alluxio.client.file.ufs.UfsFileInStream
-
- seek(long) - Method in class alluxio.file.SeekableBufferedInputStream
-
- seek(long) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
-
- seek(long) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
-
- seek(long) - Method in interface alluxio.Seekable
-
Moves the starting read position of the stream to the specified position which is relative to
the start of the stream.
- seek(long) - Method in class alluxio.underfs.cephfs.CephInputStream
-
Seek.
- seek(long) - Method in class alluxio.underfs.cephfs.CephSeekableInputStream
-
- seek(long) - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
-
- seek(long) - Method in class alluxio.underfs.hdfs.HdfsUnderFileInputStream
-
- seek(long) - Method in class alluxio.underfs.s3a.S3AInputStream
-
- Seekable - Interface in alluxio
-
This interface should be implemented by all Alluxio streams which support moving the read
position to a specific byte offset.
- SeekableBufferedInputStream - Class in alluxio.file
-
A class optimizes seekable input streams by providing buffering.
- SeekableBufferedInputStream(InputStream, int) - Constructor for class alluxio.file.SeekableBufferedInputStream
-
Constructor.
- SeekableUnderFileInputStream - Class in alluxio.underfs
-
A seekable under file input stream wrapper that encapsulates the under file input stream.
- SeekableUnderFileInputStream(InputStream) - Constructor for class alluxio.underfs.SeekableUnderFileInputStream
-
- seekToNewSource(long) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
-
- SegmentedLock - Class in alluxio.client.file.cache.cuckoofilter
-
A segmented lock that supports methods to lock/unlock multiple buckets in order to avoid dead
lock.
- SegmentedLock(int, int) - Constructor for class alluxio.client.file.cache.cuckoofilter.SegmentedLock
-
Create a segmented lock with specified locks.
- selectExecutors(BatchedJobConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.batch.BatchedJobDefinition
-
- selectExecutors(MigrateConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.migrate.MigrateDefinition
-
Selects the workers to run the task.
- selectExecutors(NoopPlanConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.NoopPlanDefinition
-
- selectExecutors(PersistConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.persist.PersistDefinition
-
- selectExecutors(T, List<WorkerInfo>, SelectExecutorsContext) - Method in interface alluxio.job.plan.PlanDefinition
-
Selects the workers to run the task.
- selectExecutors(MoveConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.replicate.MoveDefinition
-
- selectExecutors(StressBenchConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.stress.StressBenchDefinition
-
- SelectExecutorsContext - Class in alluxio.job
-
A context containing useful parameters for the job master to use when selecting the worker
that a job should execute on.
- SelectExecutorsContext(long, JobServerContext) - Constructor for class alluxio.job.SelectExecutorsContext
-
- SelectionPolicyAnyMaster - Class in alluxio.master.selectionpolicy
-
The master selection policy that connects to a random master.
- SelectionPolicyAnyMaster() - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyAnyMaster
-
- SelectionPolicyAnyStandbyMaster - Class in alluxio.master.selectionpolicy
-
The master connection mode that connects to a random standby master.
- SelectionPolicyAnyStandbyMaster() - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
-
Creates a new standby connection mode that picks the standby master randomly.
- SelectionPolicyAnyStandbyMaster(long) - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
-
Creates a new standby connection mode that
picks the standby master deterministically with a random seed.
- SelectionPolicyPrimaryMaster - Class in alluxio.master.selectionpolicy
-
The master selection policy that connects to the primary master.
- SelectionPolicyPrimaryMaster() - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyPrimaryMaster
-
- SelectionPolicySpecifiedMaster - Class in alluxio.master.selectionpolicy
-
The master selection policy that connects to the specified master.
- SelectionPolicySpecifiedMaster(InetSocketAddress) - Constructor for class alluxio.master.selectionpolicy.SelectionPolicySpecifiedMaster
-
Creates a new selection policy that specifies a master address to client.
- send(ReqT, long) - Method in class alluxio.client.block.stream.GrpcBlockingStream
-
Sends a request.
- send(ReqT) - Method in class alluxio.client.block.stream.GrpcBlockingStream
-
Sends a request.
- send(Object) - Method in class alluxio.master.transport.GrpcMessagingConnection
-
Sends a request.
- sendAndReceive(T) - Method in class alluxio.master.transport.GrpcMessagingConnection
-
Sends a request and receives a response.
- sendAsync(Message) - Method in class alluxio.master.journal.raft.RaftJournalAppender
-
Sends a request to raft server asynchronously.
- sendDataMessage(DataMessage<ReqT, DataBuffer>, long) - Method in class alluxio.client.block.stream.GrpcDataMessageBlockingStream
-
Sends a request.
- sendMessageAsync(RaftPeerId, Message) - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
Sends a message to a raft server asynchronously.
- sendMessageAsync(RaftPeerId, Message, long) - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
Sends a message to a raft server asynchronously.
- sendMessageBlocking(GrpcMessagingConnection, Object) - Method in class alluxio.master.backup.AbstractBackupRole
-
Used to send message via connection and wait until response is received.
- SENSITIVE_CONFIG_MASKER - Static variable in class alluxio.RpcUtils
-
- SensitiveConfigMask - Interface in alluxio.conf
-
Mask some sensitive information.
- SEPARATOR - Static variable in class alluxio.AlluxioURI
-
- SEPARATOR - Static variable in class alluxio.cli.hdfs.HdfsConfValidationTask
-
- SEPARATOR - Static variable in class alluxio.client.quota.CacheScope
-
- SEQUENCE_NUMBER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
- SEQUENCE_NUMBER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
-
- SERDE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.StorageFormat
-
- SERDE_PARAMETERS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
-
- SERDELIB_PARAMETERS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.StorageFormat
-
- SerializableVoid - Class in alluxio.job.util
-
Same as
Void
, but implementing Serializable.
- SerializationUtils - Class in alluxio.job.util
-
Serialization related utility methods.
- serialize(T) - Method in class alluxio.grpc.DataMessageMarshaller
-
Serialize the message to buffers.
- serialize(ReadResponse) - Method in class alluxio.grpc.ReadResponseMarshaller
-
- serialize(WriteRequest) - Method in class alluxio.grpc.WriteRequestMarshaller
-
- serialize(Object) - Static method in class alluxio.job.util.SerializationUtils
-
Serializes an object into a byte array.
- serialize(Object, String) - Static method in class alluxio.job.util.SerializationUtils
-
- serialize(Journal.JournalEntry, OutputStream) - Method in interface alluxio.master.journalv0.JournalFormatter
-
Serializes the given entry and writes it to the given output stream.
- serialize(Journal.JournalEntry, OutputStream) - Method in class alluxio.master.journalv0.ProtoBufJournalFormatter
-
- serialize() - Method in class alluxio.membership.DefaultServiceEntity
-
Serialize the ServiceEntity to bytes.
- serialize(TaggingData) - Static method in class alluxio.s3.TaggingData
-
Serializes the object as an XML (bytes).
- serialize(AccessControlList, JsonGenerator, SerializerProvider) - Method in class alluxio.security.authorization.AccessControlList.AccessControlListSerializer
-
Serialize an AccessControlList object.
- serialize() - Method in class alluxio.underfs.Fingerprint
-
- serializer() - Method in class alluxio.master.transport.GrpcMessagingContext
-
- server() - Method in class alluxio.master.transport.GrpcMessagingTransport
-
Creates a new Grpc messaging server.
- Server<T> - Interface in alluxio
-
Interface representing an Alluxio server.
- SERVER_CONFIGURATION_RESOURCE_KEY - Static variable in class alluxio.web.ProxyWebServer
-
- SERVER_VALUE - Static variable in enum alluxio.grpc.Scope
-
SERVER = 3;
- SERVERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.AddQuorumServerRequest
-
- SERVERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.QuorumServerInfo
-
- SERVERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.RemoveQuorumServerPRequest
-
- SERVERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.TransferLeadershipPRequest
-
- serveRequest(S3Handler) - Method in class alluxio.proxy.s3.S3RequestServlet
-
Core place to call S3 task's core API logic handling
function w/o exception handling.
- ServerErrorResponseEvent - Class in alluxio.client.file.dora.netty.event
-
Server error response event.
- ServerErrorResponseEvent(AlluxioStatusException) - Constructor for class alluxio.client.file.dora.netty.event.ServerErrorResponseEvent
-
Server error response event.
- SERVERINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetQuorumInfoPResponse
-
- SERVERSTATE_FIELD_NUMBER - Static variable in class alluxio.grpc.QuorumServerInfo
-
- ServerUserState - Class in alluxio.security.user
-
Server global instance of the UserState.
- service(HttpServletRequest, HttpServletResponse) - Method in class alluxio.proxy.s3.S3RequestServlet
-
Implementation to serve the HttpServletRequest and returns HttpServletResponse.
- SERVICE_NAME - Static variable in class alluxio.grpc.BlockMasterClientServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.BlockMasterWorkerServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.BlockWorkerGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.FileSystemMasterJobServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.JobMasterClientServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.JobMasterMasterServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.JobMasterWorkerServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.JournalMasterClientServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.MessagingServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.MetaMasterClientServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.MetaMasterMasterServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.MetaMasterProxyServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.MetricsMasterClientServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.PolicyMasterClientServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.RaftJournalServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.SaslAuthenticationServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.ServiceVersionClientServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.grpc.table.TableMasterClientServiceGrpc
-
- SERVICE_NAME - Static variable in class alluxio.job.ServiceConstants
-
- SERVICE_PREFIX - Static variable in class alluxio.master.AlluxioJobMasterRestServiceHandler
-
- SERVICE_PREFIX - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
-
- SERVICE_PREFIX - Static variable in class alluxio.proxy.AlluxioProxyRestServiceHandler
-
- SERVICE_PREFIX - Static variable in class alluxio.proxy.PathsRestServiceHandler
-
- SERVICE_PREFIX - Static variable in class alluxio.proxy.s3.S3RequestServlet
-
- SERVICE_PREFIX - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
-
- SERVICE_PREFIX - Static variable in class alluxio.proxy.StreamsRestServiceHandler
-
- SERVICE_PREFIX - Static variable in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
-
- SERVICE_VERSION - Static variable in class alluxio.job.ServiceConstants
-
- ServiceConstants - Class in alluxio.job
-
Alluxio job service constants.
- ServiceDiscoveryRecipe - Class in alluxio.membership
-
ServiceDiscoveryRecipe for etcd, to track health status
of all registered services.
- ServiceDiscoveryRecipe(AlluxioEtcdClient, String) - Constructor for class alluxio.membership.ServiceDiscoveryRecipe
-
CTOR for ServiceDiscoveryRecipe.
- ServiceNotFoundException - Exception in alluxio.exception
-
Exception used when the service is not provided by the server.
- ServiceNotFoundException(String, Throwable) - Constructor for exception alluxio.exception.ServiceNotFoundException
-
Constructs a new exception with the specified detail message and cause.
- ServiceType - Enum in alluxio.grpc
-
Protobuf enum alluxio.grpc.version.ServiceType
- SERVICETYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.GetServiceVersionPRequest
-
- ServiceUtils - Class in alluxio.master
-
Utility methods for Alluxio services.
- ServiceVersionClientServiceGrpc - Class in alluxio.grpc
-
- ServiceVersionClientServiceGrpc.AsyncService - Interface in alluxio.grpc
-
- ServiceVersionClientServiceGrpc.ServiceVersionClientServiceBlockingStub - Class in alluxio.grpc
-
A stub to allow clients to do synchronous rpc calls to service ServiceVersionClientService.
- ServiceVersionClientServiceGrpc.ServiceVersionClientServiceFutureStub - Class in alluxio.grpc
-
A stub to allow clients to do ListenableFuture-style rpc calls to service ServiceVersionClientService.
- ServiceVersionClientServiceGrpc.ServiceVersionClientServiceImplBase - Class in alluxio.grpc
-
Base class for the server implementation of the service ServiceVersionClientService.
- ServiceVersionClientServiceGrpc.ServiceVersionClientServiceStub - Class in alluxio.grpc
-
A stub to allow clients to do asynchronous rpc calls to service ServiceVersionClientService.
- ServiceVersionClientServiceHandler - Class in alluxio.grpc
-
This class is a gRPC handler that serves Alluxio service versions.
- ServiceVersionClientServiceHandler(Set<ServiceType>, Supplier<NodeState>) - Constructor for class alluxio.grpc.ServiceVersionClientServiceHandler
-
Creates service version handler that allows given services.
- ServiceVersionClientServiceImplBase() - Constructor for class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceImplBase
-
- serving() - Method in class alluxio.master.MasterHealthCheckClient.MasterServingHealthCheck
-
- SERVLET_PATH - Static variable in class alluxio.metrics.sink.MetricsServlet
-
- SessionCleanable - Interface in alluxio.worker
-
Interface for classes which track sessions and provide a method to clean any expired sessions.
- SessionCleaner - Class in alluxio.worker
-
SessionCleaner periodically checks if any session have become zombies, removes the zombie session
and associated data when necessary.
- SessionCleaner(Sessions, SessionCleanable...) - Constructor for class alluxio.worker.SessionCleaner
-
- SessionInfo - Class in alluxio
-
Represents one session in the worker daemon.
- SessionInfo(long, int) - Constructor for class alluxio.SessionInfo
-
- Sessions - Class in alluxio
-
Sessions
represents and manages all sessions contacting a worker.
- Sessions() - Constructor for class alluxio.Sessions
-
- set(int) - Method in interface alluxio.collections.BitSet
-
Sets the bit at the specified index to true
.
- set(int) - Method in class alluxio.collections.BuiltinBitSet
-
- set(int, T) - Method in class alluxio.collections.UnmodifiableArrayList
-
- set(PropertyKey, Object) - Method in class alluxio.conf.AlluxioProperties
-
Puts the key value pair specified by users.
- set(PropertyKey, Object) - Static method in class alluxio.conf.Configuration
-
Sets the value for the appropriate key in the
Properties
.
- set(PropertyKey, Object, Source) - Static method in class alluxio.conf.Configuration
-
Sets the value for the appropriate key in the
Properties
by source.
- set(PropertyKey, Object) - Method in class alluxio.conf.InstancedConfiguration
-
Sets the value for the appropriate key in the
Properties
.
- set(PropertyKey, String) - Method in class alluxio.conf.InstancedConfiguration
-
- set(PropertyKey, Object, Source) - Method in class alluxio.conf.InstancedConfiguration
-
Sets the value for the appropriate key in the
Properties
by source.
- set(String) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
-
- set(User) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
-
- SET_ACL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
-
- SET_ATTRIBUTE - Static variable in class alluxio.proxy.PathsRestServiceHandler
-
- SET_ATTRIBUTE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
-
- SET_BLOCKS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- SET_PERMISSION_COMMAND - Static variable in class alluxio.util.ShellUtils
-
a Unix command to set permission.
- setAccessAcl(Acl.AccessControlList) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- setAccessAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- setAccessControlException(String) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets access control exception.
- setAccessMode(Bits) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.Bits accessMode = 3;
- setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
-
- setAcl(AlluxioURI, SetAclAction, List<AclEntry>) - Method in interface alluxio.client.file.FileSystem
-
- setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in interface alluxio.client.file.FileSystem
-
Sets the ACL for a path.
- setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Sets the ACL for a path.
- setAcl(AccessControlList) - Method in class alluxio.client.file.options.OutStreamOptions
-
Sets the acl of the file.
- setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- setAcl(PAcl) - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl acl = 27;
- setAcl(PAcl.Builder) - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl acl = 27;
- setAcl(SetAclPRequest, StreamObserver<SetAclPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Sets ACL for the path.
- setAcl(SetAclPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Sets ACL for the path.
- setAcl(SetAclPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Sets ACL for the path.
- setAcl(SetAclPRequest, StreamObserver<SetAclPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Sets ACL for the path.
- SetAcl - Class in alluxio.master.backcompat.ops
-
Test for setting an ACL.
- SetAcl() - Constructor for class alluxio.master.backcompat.ops.SetAcl
-
- setAcl(List<AclEntry>) - Method in class alluxio.master.file.contexts.CreatePathContext
-
Sets an immutable copy of acl as the internal access control list.
- setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclContext) - Method in interface alluxio.master.file.FileSystemMaster
-
Sets the ACL for a path.
- setAcl(SetAclPRequest, StreamObserver<SetAclPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- setAcl(Supplier<JournalContext>, File.SetAclEntry) - Method in class alluxio.master.file.meta.InodeTree
-
- setAcl(List<AclEntry>) - Method in class alluxio.master.file.meta.MutableInode
-
Sets ACL entries into the internal ACL.
- setAcl(Acl.AccessControlList) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- setAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 6;
- setAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- setAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 15;
- setAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- setAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 19;
- setAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- setAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList acl = 14;
- setAcl(AccessControlList) - Method in class alluxio.underfs.options.CreateOptions
-
Sets an initial acl for the newly created file.
- setAcl(AccessControlList) - Method in class alluxio.wire.FileInfo
-
- SetAclAction - Enum in alluxio.grpc
-
Protobuf enum alluxio.grpc.file.SetAclAction
- SetAclContext - Class in alluxio.master.file.contexts
-
- setAclDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- setAclEntries(String, List<AclEntry>) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- setAclEntries(String, List<AclEntry>) - Method in class alluxio.underfs.BaseUnderFileSystem
-
- setAclEntries(FileSystem, String, List<AclEntry>) - Method in class alluxio.underfs.hdfs.acl.SupportedHdfsAclProvider
-
- setAclEntries(FileSystem, String, List<AclEntry>) - Method in interface alluxio.underfs.hdfs.HdfsAclProvider
-
Sets the ACL and default ACL for an hdfs path using ACL entries.
- setAclEntries(String, List<AclEntry>) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- setAclEntries(FileSystem, String, List<AclEntry>) - Method in class alluxio.underfs.hdfs.NoopHdfsAclProvider
-
- setAclEntries(String, List<AclEntry>) - Method in interface alluxio.underfs.UnderFileSystem
-
Sets the access control list of a file or directory in under file system.
- setAclEntries(String, List<AclEntry>) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- SetAclPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAclPOptions
- SetAclPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAclPOptions
- SetAclPOptionsOrBuilder - Interface in alluxio.grpc
-
- SetAclPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAclPRequest
- SetAclPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAclPRequest
- SetAclPRequestOrBuilder - Interface in alluxio.grpc
-
- SetAclPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAclPResponse
- SetAclPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAclPResponse
- SetAclPResponseOrBuilder - Interface in alluxio.grpc
-
- setAction(SetAclAction) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the set action to perform
- setAction(File.PSetAclAction) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional .alluxio.proto.journal.PSetAclAction action = 3;
- setActionId(String) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionId = 1;
- setActionId(String) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string actionId = 2;
- setActionIdBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionId = 1;
- setActionIdBytes(ByteString) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string actionId = 2;
- setActions(int, PAclAction) - Method in class alluxio.grpc.PAclEntry.Builder
-
repeated .alluxio.grpc.file.PAclAction actions = 3;
- setActions(int, Acl.AclAction) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
repeated .alluxio.proto.shared.AclAction actions = 1;
- setActions(int, Acl.AclAction) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
repeated .alluxio.proto.shared.AclAction actions = 3;
- setActions(Acl.AclActions) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional .alluxio.proto.shared.AclActions actions = 2;
- setActions(Acl.AclActions.Builder) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional .alluxio.proto.shared.AclActions actions = 2;
- setActions(AclActions) - Method in class alluxio.security.authorization.AclEntry.Builder
-
Sets a copy of actions for this entry.
- setActionsCanceled(long) - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsCanceled = 8;
- setActionsFailed(long) - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsFailed = 9;
- setActionsRunning(long) - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsRunning = 6;
- setActionsScheduled(long) - Method in class alluxio.grpc.PolicyStatus.Builder
-
metrics
- setActionsSucceeded(long) - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 actionsSucceeded = 7;
- setActionStatus(String) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionStatus = 3;
- setActionStatusBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionStatus = 3;
- setActionType(String) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionType = 2;
- setActionTypeBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string actionType = 2;
- setActiveSyncTxId(File.ActiveSyncTxIdEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
action fields.
- setActiveSyncTxId(File.ActiveSyncTxIdEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
action fields.
- setAddedBlocks(int, LocationBlockIdListEntry) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- setAddedBlocks(int, LocationBlockIdListEntry.Builder) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- setAddMountPoint(File.AddMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- setAddMountPoint(File.AddMountPointEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
- setAddQuorumServerRequest(AddQuorumServerRequest) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- setAddQuorumServerRequest(AddQuorumServerRequest.Builder) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- setAddress(NetAddress) - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.NetAddress address = 1;
- setAddress(NetAddress.Builder) - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.NetAddress address = 1;
- setAddress(WorkerNetAddress) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- setAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 2;
- setAddress(WorkerNetAddress) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- setAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
optional .alluxio.grpc.WorkerNetAddress address = 1;
- setAddress(Address) - Method in class alluxio.wire.MasterInfo
-
- setAddress(WorkerNetAddress) - Method in class alluxio.wire.WorkerInfo
-
- setAddresses(Set<String>) - Method in class alluxio.client.block.options.GetWorkerReportOptions
-
- setAddresses(int, String) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
addresses are only valid when workerRange is SPECIFIED
- setAddresses(NetAddress) - Method in class alluxio.grpc.MasterVersion.Builder
-
optional .alluxio.grpc.NetAddress addresses = 1;
- setAddresses(NetAddress.Builder) - Method in class alluxio.grpc.MasterVersion.Builder
-
optional .alluxio.grpc.NetAddress addresses = 1;
- setAddSyncPoint(File.AddSyncPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- setAddSyncPoint(File.AddSyncPointEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
- setAdvice(String) - Method in class alluxio.cli.ValidationTaskResult
-
Sets task advice.
- setAffectedPaths(int, String) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- setAlias(String...) - Method in class alluxio.conf.PropertyKey.Builder
-
- setAll(boolean) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
optional bool all = 1;
- setAllOrNone(AllOrNoneSet) - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- setAllOrNone(AllOrNoneSet.Builder) - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- setAllowed(boolean) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional bool allowed = 2;
- setAllowed(boolean) - Method in interface alluxio.master.audit.AuditContext
-
Set to true if the operation associated with this
AuditContext
is allowed, false
otherwise.
- setAllowed(boolean) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
- setAllowed(boolean) - Method in class alluxio.master.job.JobMasterAuditContext
-
- setAllowed(boolean) - Method in class alluxio.s3.S3AuditContext
-
- setAllowedOnStandbyMasters(boolean) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
optional bool allowedOnStandbyMasters = 2;
- setAllowExists(boolean) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool allowExists = 2;
- setAllowLeader(boolean) - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool allowLeader = 3;
- setAllThroughput(List<Long>) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- setAlluxioOnly(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool alluxioOnly = 2;
- setAlluxioOnly(boolean) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
Deprecated, this field is about whether to delete in the UFS.
- setAlluxioPath(String) - Method in class alluxio.grpc.File.Builder
-
optional string alluxio_path = 1;
- setAlluxioPath(String) - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of alluxio mount point
- setAlluxioPath(String) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
optional string alluxioPath = 1;
- setAlluxioPath(String) - Method in class alluxio.grpc.UnmountPRequest.Builder
-
the path of the alluxio mount point
- setAlluxioPath(String) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
the path of alluxio mount point
- setAlluxioPath(String) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string alluxio_path = 1;
- setAlluxioPath(String) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
optional string alluxio_path = 1;
- setAlluxioPath(String) - Method in class alluxio.worker.block.CreateBlockOptions
-
- setAlluxioPathBytes(ByteString) - Method in class alluxio.grpc.File.Builder
-
optional string alluxio_path = 1;
- setAlluxioPathBytes(ByteString) - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of alluxio mount point
- setAlluxioPathBytes(ByteString) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
optional string alluxioPath = 1;
- setAlluxioPathBytes(ByteString) - Method in class alluxio.grpc.UnmountPRequest.Builder
-
the path of the alluxio mount point
- setAlluxioPathBytes(ByteString) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
the path of alluxio mount point
- setAlluxioPathBytes(ByteString) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string alluxio_path = 1;
- setAlluxioPathBytes(ByteString) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
optional string alluxio_path = 1;
- setAlluxioVersion(String) - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- setAlluxioVersion(String) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional string alluxioVersion = 3;
- setAlluxioVersionBytes(ByteString) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional string alluxioVersion = 3;
- setAlluxioWorkDirectory(String) - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Sets Alluxio work directory.
- setAsync(boolean) - Method in class alluxio.grpc.CacheRequest.Builder
-
optional bool async = 6;
- setAsyncPersistOptions(ScheduleAsyncPersistencePOptions) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- setAsyncPersistOptions(ScheduleAsyncPersistencePOptions.Builder) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- setAsyncPersistRequest(File.AsyncPersistRequestEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- setAsyncPersistRequest(File.AsyncPersistRequestEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- setAsyncRestoreEnabled(boolean) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setAsyncWriteThreads(int) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setAttribute(SetAttributePRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
-
SetAttribute for a file or dir.
- setAttribute(SetAttributePRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
-
- setAttribute(String, SetAttributePOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
-
Set attributes for a file or dir.
- setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
-
- setAttribute(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
-
- setAttribute(AlluxioURI, SetAttributePOptions) - Method in interface alluxio.client.file.FileSystem
-
Sets any number of a path's attributes, such as TTL and pin status.
- setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- setAttribute(AlluxioURI, SetAttributePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Sets the file or directory attributes.
- setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- setAttribute(FileSystem, AlluxioURI, SetAttributePOptions) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
Sets attribute for a file.
- setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
-
Sets file or directory attributes.
- setAttribute(SetAttributePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
-
Sets file or directory attributes.
- setAttribute(SetAttributePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
-
Sets file or directory attributes.
- setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
-
Sets file or directory attributes.
- setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Sets file or directory attributes.
- setAttribute(SetAttributePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Sets file or directory attributes.
- setAttribute(SetAttributePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Sets file or directory attributes.
- setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Sets file or directory attributes.
- setAttribute(AlluxioURI, SetAttributeContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- setAttribute(AlluxioURI, SetAttributeContext) - Method in interface alluxio.master.file.FileSystemMaster
-
Sets the file attribute.
- setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- setAttribute(String, SetAttributePOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
-
- setAttribute(String, SetAttributePOptions) - Method in interface alluxio.worker.dora.DoraWorker
-
Set Attributes for a file or dir.
- setAttribute(String, SetAttributePOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
-
Set attribute for this file/dir.
- setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
-
- setAttributeClientDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
Defaults for the SetAttribute RPC which should only be used on the client side.
- SetAttributeContext - Class in alluxio.master.file.contexts
-
- setAttributeDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
-
- SetAttributePOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAttributePOptions
- SetAttributePOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAttributePOptions
- SetAttributePOptionsOrBuilder - Interface in alluxio.grpc
-
- SetAttributePRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAttributePRequest
- SetAttributePRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAttributePRequest
- SetAttributePRequestOrBuilder - Interface in alluxio.grpc
-
- SetAttributePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAttributePResponse
- SetAttributePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SetAttributePResponse
- SetAttributePResponseOrBuilder - Interface in alluxio.grpc
-
- setAttributeSingleFile(RpcContext, LockedInodePath, boolean, long, SetAttributeContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- setAuthenticatedUserInfo(AuthenticatedUserInfo) - Method in class alluxio.security.authentication.plain.SaslServerHandlerPlain
-
- setAuthenticatedUserInfo(AuthenticatedUserInfo) - Method in interface alluxio.security.authentication.SaslServerHandler
-
To be called by callbacks to store authenticated user information.
- setAuthenticationScheme(ChannelAuthenticationScheme) - Method in class alluxio.grpc.SaslMessage.Builder
-
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
- setAuthMethod(String) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
-
Sets the connection authentication method to the
ThreadLocal
variable.
- setAuthType(AuthType) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
Sets mAuthType field.
- setAuthType(AuthType) - Method in class alluxio.master.job.JobMasterAuditContext
-
Sets mAuthType field.
- setAvgColLen(double) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional double avg_col_len = 2;
- setAvgColLen(double) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional double avg_col_len = 2;
- setBackupError(ByteString) - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional bytes backupError = 6;
- setBackupHost(String) - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupHost = 3;
- setBackupHostBytes(ByteString) - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupHost = 3;
- setBackupId(String) - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupId = 1;
- setBackupId(String) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
optional string backupId = 1;
- setBackupId(UUID) - Method in class alluxio.wire.BackupStatus
-
Sets the unique backup id.
- setBackupIdBytes(ByteString) - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupId = 1;
- setBackupIdBytes(ByteString) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
optional string backupId = 1;
- setBackupManager(BackupManager) - Method in class alluxio.master.CoreMasterContext.Builder
-
- setBackupState(BackupState) - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional .alluxio.grpc.meta.BackupState backupState = 2;
- setBackupUri(String) - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupUri = 4;
- setBackupUri(AlluxioURI) - Method in class alluxio.wire.BackupStatus
-
Sets the backup uri.
- setBackupUriBytes(ByteString) - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional string backupUri = 4;
- setBandwidth(long) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional int64 bandwidth = 1;
- setBandwidth(long) - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional int64 bandwidth = 1;
- setBandwidth(long) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional int64 bandwidth = 1;
- setBandwidth(long) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
optional int64 bandwidth = 3;
- setBandwidth(long) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional int64 bandwidth = 4;
- setBandwidth(long) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional int64 bandwidth = 3;
- setBandwidth(long) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional int64 bandwidth = 4;
- setBaseLayout(Layout) - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- setBaseLayout(Layout.Builder) - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.Layout base_layout = 2;
- setBaseParameters(BaseParameters) - Method in class alluxio.stress.client.ClientIOSummary
-
- setBaseParameters(BaseParameters) - Method in class alluxio.stress.client.ClientIOTaskResult
-
- setBaseParameters(BaseParameters) - Method in class alluxio.stress.worker.IOTaskResult
-
- setBaseParameters(BaseParameters) - Method in class alluxio.stress.worker.IOTaskSummary
-
- setBaseParameters(BaseParameters) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- setBatchSize(int) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Batch size for partial listings.
- setBinaryStats(BinaryColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- setBinaryStats(BinaryColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- setBits(Bits) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.Bits bits = 1;
- setBitVectors(String) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional string bit_vectors = 4;
- setBitVectors(String) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional string bit_vectors = 4;
- setBitVectors(String) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional string bit_vectors = 5;
- setBitVectors(String) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional string bit_vectors = 5;
- setBitVectors(String) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional string bit_vectors = 5;
- setBitVectors(String) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional string bit_vectors = 5;
- setBitVectors(String) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional string bit_vectors = 5;
- setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional string bit_vectors = 4;
- setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional string bit_vectors = 4;
- setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional string bit_vectors = 5;
- setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional string bit_vectors = 5;
- setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional string bit_vectors = 5;
- setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional string bit_vectors = 5;
- setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional string bit_vectors = 5;
- setBlock(Block) - Method in class alluxio.grpc.BlockStatus.Builder
-
required .alluxio.grpc.block.Block block = 1;
- setBlock(Block.Builder) - Method in class alluxio.grpc.BlockStatus.Builder
-
required .alluxio.grpc.block.Block block = 1;
- setBlockContainerIdGenerator(Block.BlockContainerIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- setBlockContainerIdGenerator(Block.BlockContainerIdGeneratorEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
- setBlockCount(long) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
- setBlockCount(long) - Method in class alluxio.wire.WorkerInfo
-
- setBlockCount(String) - Method in class alluxio.wire.WorkerWebUIOverview
-
Sets worker block count.
- setBlockId(long) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.grpc.Block.Builder
-
required int64 block_id = 1;
- setBlockId(int, long) - Method in class alluxio.grpc.BlockIdList.Builder
-
repeated int64 blockId = 1;
- setBlockId(long) - Method in class alluxio.grpc.BlockInfo.Builder
-
optional int64 blockId = 1;
- setBlockId(long) - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the id of the block being committed
- setBlockId(long) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
the id of the block
- setBlockId(long) - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
optional int64 block_id = 1;
- setBlockId(long) - Method in class alluxio.wire.BlockInfo
-
- setBlockIds(int, long) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated int64 blockIds = 13;
- setBlockIds(int, long) - Method in class alluxio.grpc.PersistFile.Builder
-
repeated int64 blockIds = 2;
- setBlockIds(List<Long>) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setBlockIds(int, long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
repeated int64 block_ids = 1;
- setBlockIds(List<Long>) - Method in class alluxio.wire.FileInfo
-
- setBlockIds(List<Long>) - Method in class alluxio.wire.PersistFile
-
Set the block ids.
- setBlockInfo(BlockInfo) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- setBlockInfo(BlockInfo.Builder) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- setBlockInfo(BlockInfo) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- setBlockInfo(BlockInfo.Builder) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
optional .alluxio.grpc.BlockInfo blockInfo = 1;
- setBlockInfo(Block.BlockInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- setBlockInfo(Block.BlockInfoEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
- setBlockInfo(BlockInfo) - Method in class alluxio.wire.FileBlockInfo
-
- setBlockLocation(BlockLocation) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- setBlockLocation(BlockLocation.Builder) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional .alluxio.grpc.BlockLocation block_location = 3;
- setBlockMasterInfo(BlockMasterInfo) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- setBlockMasterInfo(BlockMasterInfo.Builder) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
- setBlockReader(BlockReader) - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- setBlockReader(BlockReader) - Method in class alluxio.worker.netty.BlockReadRequestContext
-
- setBlocks(int, Block) - Method in class alluxio.grpc.LoadRequest.Builder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- setBlocks(int, Block.Builder) - Method in class alluxio.grpc.LoadRequest.Builder
-
repeated .alluxio.grpc.block.Block blocks = 1;
- setBlocks(int, long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated int64 blocks = 12;
- setBlocks(int, long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated int64 blocks = 16;
- setBlockSize(long) - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional int64 block_size = 3;
- setBlockSize(long) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The block size.
- setBlockSize(long) - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- setBlockSizeBytes(long) - Method in class alluxio.client.file.options.OutStreamOptions
-
Sets the size of the block in bytes.
- setBlockSizeBytes(long) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int64 blockSizeBytes = 1;
- setBlockSizeBytes(long) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 blockSizeBytes = 6;
- setBlockSizeBytes(long) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setBlockSizeBytes(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 block_size_bytes = 8;
- setBlockSizeBytes(long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 block_size_bytes = 2;
- setBlockSizeBytes(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
file only
- setBlockSizeBytes(long) - Method in class alluxio.wire.FileInfo
-
- setBlockSizeBytes(String) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets block size bytes.
- setBlockSizeBytes(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Sets block size bytes.
- setBlockStatus(int, BlockStatus) - Method in class alluxio.grpc.LoadResponse.Builder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- setBlockStatus(int, BlockStatus.Builder) - Method in class alluxio.grpc.LoadResponse.Builder
-
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
- setBlockStoreFactory(BlockMetaStore.Factory) - Method in class alluxio.master.CoreMasterContext.Builder
-
- setBlockWriter(BlockWriter) - Method in class alluxio.worker.netty.BlockWriteRequestContext
-
- setBooleanStats(BooleanColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- setBooleanStats(BooleanColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- setBooleanType(boolean) - Method in class alluxio.grpc.table.Value.Builder
-
bool boolean_type = 4;
- setBucket(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- setBucket(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
-
- setBucket(String) - Method in class alluxio.proxy.s3.ListMultipartUploadsResult
-
- setBucket(String) - Method in class alluxio.proxy.s3.ListPartsResult
-
- setBucket(String) - Method in class alluxio.s3.S3AuditContext
-
Sets mBucket field.
- setBucketAndSlot(int, int) - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
-
Set the bucket and slot.
- setBucketCount(long) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
optional int64 bucket_count = 2;
- setBucketedBy(int, String) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated string bucketed_by = 1;
- setBucketIndex(int) - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
-
Set the bucket index.
- setBucketProperty(HiveBucketProperty) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- setBucketProperty(HiveBucketProperty.Builder) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- setBuckets(List<ListAllMyBucketsResult.Bucket>) - Method in class alluxio.s3.ListAllMyBucketsResult
-
- setBuildVersion(BuildVersion) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
the worker version to display in info pages (useful for rolling upgrades)
- setBuildVersion(BuildVersion.Builder) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
the worker version to display in info pages (useful for rolling upgrades)
- setBuildVersion(BuildVersion) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- setBuildVersion(BuildVersion.Builder) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional .alluxio.grpc.BuildVersion buildVersion = 10;
- setBuildVersion(BuildVersion) - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
Sets the build version of the worker.
- setBypassDelegation(boolean) - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool bypassDelegation = 4;
- setBytes(long) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
optional int64 bytes = 1;
- setBytes(long) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
optional int64 bytes = 1;
- setBytesReserved(long) - Method in class alluxio.worker.netty.BlockWriteRequestContext
-
- setBytesSkipped(long) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
optional int64 bytes_skipped = 4;
- setCacheable(boolean) - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool cacheable = 11;
- setCacheable(boolean) - Method in class alluxio.master.file.contexts.CreateFileContext
-
- setCacheable(boolean) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setCacheable(boolean) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool cacheable = 11;
- setCacheable(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional bool cacheable = 5;
- setCacheable(boolean) - Method in class alluxio.wire.FileInfo
-
- setCacheEnabled(boolean) - Method in class alluxio.client.file.cache.context.CachePerThreadContext
-
- setCacheEvictorOptions(CacheEvictorOptions) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setCacheHit(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets cache hit.
- setCacheIdentifier(String) - Method in class alluxio.client.file.CacheContext
-
- setCacheMiss(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets cache miss.
- setCacheQuota(CacheQuota) - Method in class alluxio.client.file.CacheContext
-
- setCacheScope(CacheScope) - Method in class alluxio.client.file.CacheContext
-
- setCacheSize(long) - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- setCacheSize(long) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional int64 cacheSize = 2;
- setCancel(boolean) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
optional bool cancel = 2;
- setCancel(boolean) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
If set, this request is to cancel the reading request for the id.
- setCancel(boolean) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional bool cancel = 6;
- setCancel(boolean) - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- setCancel(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
-
- setCancelState(PersistJob.CancelState) - Method in class alluxio.master.file.PersistJob
-
- setCancelTaskCommand(CancelTaskCommand) - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- setCancelTaskCommand(CancelTaskCommand.Builder) - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- setCandidates(int, Value) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- setCandidates(int, Value.Builder) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- setCanRegisterAgain(boolean) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
optional bool canRegisterAgain = 3;
- setCapacity(Capacity) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setCapacity(Capacity) - Method in class alluxio.wire.AlluxioWorkerInfo
-
- setCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets capacity.
- setCapacityBytes(long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 capacityBytes = 1;
- setCapacityBytes(long) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 capacityBytes = 5;
- setCapacityBytes(long) - Method in class alluxio.wire.BlockMasterInfo
-
- setCapacityBytes(long) - Method in class alluxio.wire.WorkerInfo
-
- setCapacityBytes(String) - Method in class alluxio.wire.WorkerWebUIOverview
-
Sets capacity bytes.
- setCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.BlockMasterInfo
-
- setCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.WorkerInfo
-
- setChannel(Channel) - Method in class alluxio.network.netty.NettyRPCContext
-
- setChannelRef(String) - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string channelRef = 5;
- setChannelRefBytes(ByteString) - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string channelRef = 5;
- setCheckContent(boolean) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool check_content = 6;
- setCheckContent(boolean) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool check_content = 6;
- setCheckContent(boolean) - Method in class alluxio.grpc.WriteOptions.Builder
-
optional bool check_content = 3;
- setCheckContent(boolean) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional bool check_content = 11;
- setCheckContent(boolean) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional bool check_content = 11;
- setCheckS3BucketPath(boolean) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool checkS3BucketPath = 8;
- setCheckS3BucketPath(boolean) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool checkS3BucketPath = 14;
- setCheckUfs(boolean) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
optional bool checkUfs = 1;
- setChildCount(long) - Method in class alluxio.master.file.meta.MutableInodeDirectory
-
- setChildCount(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 child_count = 26;
- setChildren(int, JobInfo) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- setChildren(int, JobInfo.Builder) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- setChunk(Chunk) - Method in class alluxio.grpc.ReadResponse.Builder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- setChunk(Chunk.Builder) - Method in class alluxio.grpc.ReadResponse.Builder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- setChunk(ByteString) - Method in class alluxio.grpc.SnapshotData.Builder
-
optional bytes chunk = 3;
- setChunk(Chunk) - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- setChunk(Chunk.Builder) - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- setChunkSize(long) - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 chunk_size = 5;
- setChunkSize(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
If set, the server should send packets in the specified packet size.
- setClassName(String) - Method in interface alluxio.util.JsonSerializable
-
- setClient(AmazonS3) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- setClientId(String) - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string clientId = 3;
- setClientIdBytes(ByteString) - Method in class alluxio.grpc.SaslMessage.Builder
-
optional string clientId = 3;
- setClientMetrics(int, ClientMetrics) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- setClientMetrics(int, ClientMetrics.Builder) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
- setClientObserver(StreamObserver<SaslMessage>) - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
-
Sets the client's Sasl stream.
- setClientVersion(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
set client version.
- setClientVersion(String) - Method in class alluxio.master.job.JobMasterAuditContext
-
Sets client version.
- setClusterConf(AlluxioConfiguration) - Method in class alluxio.ClientContext
-
- setClusterConfHash(String) - Method in class alluxio.ClientContext
-
- setClusterConfHash(String) - Method in class alluxio.wire.Configuration.Builder
-
Sets hash of path configurations.
- setClusterConfigHash(String) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string clusterConfigHash = 1;
- setClusterConfigHash(String) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string clusterConfigHash = 3;
- setClusterConfigHash(String) - Method in class alluxio.wire.WorkerWebUIConfiguration
-
Sets cluster config hash.
- setClusterConfigHashBytes(ByteString) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string clusterConfigHash = 1;
- setClusterConfigHashBytes(ByteString) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string clusterConfigHash = 3;
- setClusterConfigLastUpdateTime(long) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional int64 clusterConfigLastUpdateTime = 5;
- setClusterConfigLastUpdateTime(String) - Method in class alluxio.wire.WorkerWebUIConfiguration
-
Sets cluster config last update time.
- setClusterConfigs(int, ConfigProperty) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- setClusterConfigs(int, ConfigProperty.Builder) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
- setClusterConfLastUpdateTime(long) - Method in class alluxio.wire.Configuration.Builder
-
Sets cluster config last update time.
- setClusterId(String) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string clusterId = 11;
- setClusterId(String) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
optional string cluster_id = 1;
- setClusterId(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets cluster id.
- setClusterIdBytes(ByteString) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string clusterId = 11;
- setClusterIdBytes(ByteString) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
optional string cluster_id = 1;
- setClusterInfo(Meta.ClusterInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- setClusterInfo(Meta.ClusterInfoEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- setClusterName(String) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
-
- setCmdConfig(ByteString) - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional bytes cmdConfig = 1;
- setCmdProgress(CmdProgress) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- setCmdProgress(CmdProgress.Builder) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
- setCmdStatus(Status) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
optional .alluxio.grpc.job.Status cmdStatus = 1;
- setCmdStatusBlock(CmdStatusBlock) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- setCmdStatusBlock(CmdStatusBlock.Builder) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
- setCode(int) - Method in class alluxio.grpc.BlockStatus.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- setCode(int) - Method in class alluxio.grpc.FileFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- setCode(int) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- setCode(int) - Method in class alluxio.grpc.RouteFailure.Builder
-
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
- setCode(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- setCode(String) - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
-
Sets the code of this result.
- setCode(String) - Method in class alluxio.s3.S3Error
-
- setColName(String) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_name = 1;
- setColNameBytes(ByteString) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_name = 1;
- setColNames(int, String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- setColNames(int, String) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
repeated string col_names = 3;
- setCols(int, FieldSchema) - Method in class alluxio.grpc.table.Schema.Builder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- setCols(int, FieldSchema.Builder) - Method in class alluxio.grpc.table.Schema.Builder
-
repeated .alluxio.grpc.table.FieldSchema cols = 1;
- setColType(String) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_type = 2;
- setColTypeBytes(ByteString) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional string col_type = 2;
- setColumnName(String) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
required string column_name = 1;
- setColumnNameBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
required string column_name = 1;
- setCommand(Command) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
optional .alluxio.grpc.Command command = 1;
- setCommand(Command.Builder) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
optional .alluxio.grpc.Command command = 1;
- setCommand(FileSystemCommand) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- setCommand(FileSystemCommand.Builder) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- setCommand(JobMasterMetaCommand) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
- setCommand(MetaCommand) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
optional .alluxio.grpc.meta.MetaCommand command = 1;
- setCommand(WriteRequestCommand) - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- setCommand(WriteRequestCommand.Builder) - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- setCommand(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
Sets mCommand field.
- setCommand(String) - Method in class alluxio.master.job.JobMasterAuditContext
-
Sets mCommand field.
- setCommand(String) - Method in class alluxio.s3.S3AuditContext
-
Sets mCommand field.
- setCommandOptions(FileSystemCommandOptions) - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- setCommandOptions(FileSystemCommandOptions.Builder) - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
- setCommandOptions(FileSystemCommandOptions) - Method in class alluxio.wire.FileSystemCommand
-
Set the command options.
- setCommands(int, JobCommand) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- setCommands(int, JobCommand.Builder) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- setCommandType(CommandType) - Method in class alluxio.grpc.Command.Builder
-
optional .alluxio.grpc.CommandType commandType = 1;
- setCommandType(CommandType) - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.CommandType commandType = 1;
- setCommandType(CommandType) - Method in class alluxio.wire.FileSystemCommand
-
Set the command type.
- setComment(String) - Method in class alluxio.grpc.table.Database.Builder
-
optional string comment = 7;
- setComment(String) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string comment = 4;
- setCommentBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
-
optional string comment = 7;
- setCommentBytes(ByteString) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string comment = 4;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.UnmountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.UnmountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- setCommonOptions(Cache.PPageStoreCommonOptions) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- setCommonOptions(Cache.PPageStoreCommonOptions.Builder) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
- setCompleted(boolean) - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool completed = 8;
- setCompleted(boolean) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setCompleted(boolean) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool completed = 10;
- setCompleted(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional bool completed = 4;
- setCompleted(boolean) - Method in class alluxio.wire.FileInfo
-
- setCompleteFile(File.CompleteFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- setCompleteFile(File.CompleteFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- setConfig(JobConfig) - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Set job config.
- setConfigCheckErrorNum(int) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets config check error num.
- setConfigCheckErrors(Map<Scope, List<InconsistentProperty>>) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets config check errors.
- setConfigCheckStatus(ConfigStatus) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets config check status.
- setConfigCheckWarnNum(int) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets config check warn num.
- setConfigCheckWarns(Map<Scope, List<InconsistentProperty>>) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets config check warns.
- setConfigHash(ConfigHash) - Method in class alluxio.wire.MasterWebUIConfiguration
-
Sets config hash.
- setConfigs(int, ConfigProperty) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- setConfigs(int, ConfigProperty.Builder) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- setConfigs(int, ConfigProperty) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- setConfigs(int, ConfigProperty.Builder) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
repeated .alluxio.grpc.ConfigProperty configs = 1;
- setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioJobWorkerInfo
-
- setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioProxyInfo
-
- setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioWorkerInfo
-
- setConfiguration(TreeSet<Triple<String, String, String>>) - Method in class alluxio.wire.MasterWebUIConfiguration
-
Sets configuration.
- setConfiguration(TreeSet<Triple<String, String, String>>) - Method in class alluxio.wire.WorkerWebUIConfiguration
-
Sets configuration.
- setConnection(GrpcMessagingConnection) - Method in class alluxio.master.backup.BackupHandshakeMessage
-
- setConnectionUser(String) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
-
- setConsistencyCheckLevel(PropertyKey.ConsistencyCheckLevel) - Method in class alluxio.conf.PropertyKey.Builder
-
- setConstraint(Constraint) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- setConstraint(Constraint.Builder) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional .alluxio.grpc.table.Constraint constraint = 3;
- setContainerHost(String) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string containerHost = 7;
- setContainerHost(String) - Method in class alluxio.wire.WorkerNetAddress
-
- setContainerHostBytes(ByteString) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string containerHost = 7;
- setContainerId(long) - Method in class alluxio.master.file.state.DirectoryId
-
- setContainerId(long) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
optional int64 container_id = 1;
- setContentHash(String) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional string contentHash = 4;
- setContentHash(String) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string contentHash = 34;
- setContentHash(String) - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional string content_hash = 1;
- setContentHash(String) - Method in class alluxio.grpc.WriteResponse.Builder
-
Errors will be handled by standard gRPC stream APIs.
- setContentHash(String) - Method in class alluxio.wire.FileInfo
-
- setContentHash(String) - Method in class alluxio.worker.grpc.WriteRequestContext
-
- setContentHashBytes(ByteString) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional string contentHash = 4;
- setContentHashBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string contentHash = 34;
- setContentHashBytes(ByteString) - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional string content_hash = 1;
- setContentHashBytes(ByteString) - Method in class alluxio.grpc.WriteResponse.Builder
-
Errors will be handled by standard gRPC stream APIs.
- setContentLength(long) - Method in class alluxio.grpc.UfsFileStatus.Builder
-
optional int64 content_length = 2;
- setContext(GrpcMessagingContext) - Method in class alluxio.master.transport.GrpcMessagingThread
-
Sets the Grpc messaging context.
- setContinuationToken(String) - Method in class alluxio.s3.ListBucketOptions
-
- setCopyJob(Job.CopyJobEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- setCopyJob(Job.CopyJobEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
- setCount(long) - Method in class alluxio.grpc.StatusSummary.Builder
-
optional int64 count = 2;
- setCounter(Counter) - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- setCounter(Counter) - Method in class alluxio.worker.grpc.WriteRequestContext
-
- setCounter(Counter) - Method in class alluxio.worker.netty.ReadRequestContext
-
- setCounter(Counter) - Method in class alluxio.worker.netty.WriteRequestContext
-
- setCreateAncestors(boolean) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional bool createAncestors = 2;
- setCreatedAt(long) - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional int64 created_at = 3;
- setCreatedAt(long) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional int64 created_at = 3;
- setCreateOptions(CreateOptions) - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
-
- setCreateOptions(CreateOptions) - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
-
- setCreateParent(boolean) - Method in class alluxio.underfs.options.CreateOptions
-
Sets option to force creation of parent directories.
- setCreateParent(boolean) - Method in class alluxio.underfs.options.MkdirsOptions
-
Sets option to create parent directories.
- setCreateUfsFileOptions(Protocol.CreateUfsFileOptions) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- setCreateUfsFileOptions(Protocol.CreateUfsFileOptions.Builder) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
Cancel, close and error will be handled by standard gRPC stream APIs.
- setCreateUfsFileOptions(Protocol.CreateUfsFileOptions) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for ufs writes.
- setCreateUfsFileOptions(Protocol.CreateUfsFileOptions.Builder) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for ufs writes.
- setCreationDate(String) - Method in class alluxio.s3.ListAllMyBucketsResult.Bucket
-
- setCreationTimeMs(long) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 creationTimeMs = 7;
- setCreationTimeMs(long) - Method in class alluxio.master.file.meta.MutableInode
-
- setCreationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 creation_time_ms = 6;
- setCreationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 creation_time_ms = 6;
- setCreationTimeMs(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 creation_time_ms = 6;
- setCreationTimeMs(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 creation_time_ms = 2;
- setCreationTimeMs(long) - Method in class alluxio.wire.FileInfo
-
- setCreationTimeNs(long) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
Sets mCreationTimeNs field.
- setCreationTimeNs(long) - Method in class alluxio.master.job.JobMasterAuditContext
-
Sets mCreationTimeNs field.
- setCreationTimeNs(long) - Method in class alluxio.s3.S3AuditContext
-
Sets mCreationTimeNs field.
- setCurrentBlocks(int, LocationBlockIdListEntry) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- setCurrentBlocks(int, LocationBlockIdListEntry.Builder) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- setCurrentContent(ByteBuf) - Method in class alluxio.s3.MultiChunkEncodingInputStream
-
Sets currentContent with given content.
- setCurrentDirectory(UIFileInfo) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets current directory.
- setCurrentPath(String) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets current path.
- setCurrentPath(String) - Method in class alluxio.wire.MasterWebUILogs
-
Sets current path.
- setCurrentPath(String) - Method in class alluxio.wire.WorkerWebUILogs
-
Sets current path.
- setData(ByteString) - Method in class alluxio.grpc.Chunk.Builder
-
optional bytes data = 1;
- setData(int, long) - Method in class alluxio.grpc.Command.Builder
-
repeated int64 data = 2;
- setData(SnapshotData) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- setData(SnapshotData.Builder) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- setData(ColumnStatisticsData) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- setData(ColumnStatisticsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- setData(SnapshotData) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- setData(SnapshotData.Builder) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- setData(List<WorkerBenchDataPoint>) - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
-
- setDatabase(int, String) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
repeated string database = 1;
- setDatabase(String) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
optional string database = 1;
- setDatabaseBytes(ByteString) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
optional string database = 1;
- setDataCacheEnabled(boolean) - Method in class alluxio.client.file.options.FileSystemOptions.Builder
-
- setDataCols(int, FieldSchema) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- setDataCols(int, FieldSchema.Builder) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- setDataPort(int) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 dataPort = 3;
- setDataPort(int) - Method in class alluxio.wire.WorkerNetAddress
-
- setDataReaderActive(boolean) - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- setDateStats(DateColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- setDateStats(DateColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- setDaysSinceEpoch(long) - Method in class alluxio.grpc.table.Date.Builder
-
required int64 days_since_epoch = 1;
- setDb(Database) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
optional .alluxio.grpc.table.Database db = 1;
- setDb(Database.Builder) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
optional .alluxio.grpc.table.Database db = 1;
- setDbName(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string db_name = 4;
- setDbName(String) - Method in class alluxio.grpc.table.Database.Builder
-
optional string db_name = 1;
- setDbName(String) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
optional string db_name = 1;
- setDbName(String) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
optional string db_name = 1;
- setDbName(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- setDbName(String) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- setDbName(String) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string db_name = 1;
- setDbName(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string db_name = 3;
- setDbName(String) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string db_name = 1;
- setDbName(String) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
optional string db_name = 1;
- setDbName(String) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string db_name = 1;
- setDbName(String) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string db_name = 1;
- setDbName(String) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string db_name = 4;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string db_name = 3;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string db_name = 1;
- setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string db_name = 1;
- setDebug(boolean) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets debug.
- setDebug(boolean) - Method in class alluxio.wire.MasterWebUIInit
-
Sets debug.
- setDebug(boolean) - Method in class alluxio.wire.MasterWebUILogs
-
Sets debug.
- setDebug(boolean) - Method in class alluxio.wire.MasterWebUIMasters
-
Sets debug.
- setDebug(boolean) - Method in class alluxio.wire.MasterWebUIMountTable
-
Sets debug.
- setDebug(boolean) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets debug.
- setDebug(boolean) - Method in class alluxio.wire.MasterWebUIWorkers
-
Sets debug.
- setDebug(boolean) - Method in class alluxio.wire.WorkerWebUIInit
-
Sets debug.
- setDebug(boolean) - Method in class alluxio.wire.WorkerWebUILogs
-
Sets debug.
- setDecimalStats(DecimalColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- setDecimalStats(DecimalColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- setDecommissionedWorkerNum(int) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 decommissionedWorkerNum = 8;
- setDefault(boolean) - Method in class alluxio.security.authorization.AclEntry
-
Sets the entry to be default.
- setDefaultAcl(PAcl) - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- setDefaultAcl(PAcl.Builder) - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
- setDefaultAcl(List<AclEntry>) - Method in class alluxio.master.file.contexts.CreateDirectoryContext
-
Sets the default ACL in the context.
- setDefaultACL(DefaultAccessControlList) - Method in class alluxio.master.file.meta.MutableInode
-
- setDefaultACL(DefaultAccessControlList) - Method in class alluxio.master.file.meta.MutableInodeDirectory
-
- setDefaultACL(DefaultAccessControlList) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setDefaultAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- setDefaultAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
- setDefaultAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- setDefaultAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
- setDefaultAcl(Acl.AccessControlList) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- setDefaultAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
- setDefaultAcl(DefaultAccessControlList) - Method in class alluxio.wire.FileInfo
-
- setDefaultSupplier(DefaultSupplier) - Method in class alluxio.conf.PropertyKey.Builder
-
- setDefaultSupplier(Supplier<Object>, String) - Method in class alluxio.conf.PropertyKey.Builder
-
- setDefaultTaskExecutorPoolSize(int) - Method in class alluxio.worker.job.task.TaskExecutorManager
-
Sets the number of threads in the task executor pool when not throttled.
- setDefaultValue(Object) - Method in class alluxio.conf.PropertyKey.Builder
-
- setDefinition(String) - Method in class alluxio.grpc.table.Transformation.Builder
-
optional string definition = 2;
- setDefinition(String) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string definition = 3;
- setDefinition(String) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string definition = 3;
- setDefinitionBytes(ByteString) - Method in class alluxio.grpc.table.Transformation.Builder
-
optional string definition = 2;
- setDefinitionBytes(ByteString) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string definition = 3;
- setDefinitionBytes(ByteString) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string definition = 3;
- setDelay(long) - Method in class alluxio.util.executor.ControllableQueue.DelayNode
-
Sets the delay.
- setDeleteBlock(Block.DeleteBlockEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- setDeleteBlock(Block.DeleteBlockEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
- setDeleted(boolean) - Method in class alluxio.master.file.meta.MutableInode
-
- setDeleted(List<DeleteObjectsResult.DeletedObject>) - Method in class alluxio.s3.DeleteObjectsResult
-
Sets the set of deleted objects.
- setDeleteFile(File.DeleteFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- setDeleteFile(File.DeleteFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
- setDeleteMarker(String) - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
-
Sets the delete marker of this delete result.
- setDeleteMarkerVersionId(String) - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
-
Sets the version id of delete marker.
- setDeleteMountPoint(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool deleteMountPoint = 6;
- setDeleteMountPoint(File.DeleteMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- setDeleteMountPoint(File.DeleteMountPointEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
- setDeleteObject(List<DeleteObjectsRequest.DeleteObject>) - Method in class alluxio.s3.DeleteObjectsRequest
-
Set of items to delete.
- setDelimiter(String) - Method in class alluxio.conf.PropertyKey.Builder
-
- setDelimiter(String) - Method in class alluxio.s3.ListBucketOptions
-
- setDesc(String) - Method in class alluxio.cli.ValidationTaskResult
-
Sets task name.
- setDescription(String) - Method in class alluxio.conf.PropertyKey.Builder
-
- setDescription(String) - Method in class alluxio.grpc.JobInfo.Builder
-
optional string description = 13;
- setDescription(String) - Method in class alluxio.grpc.table.Database.Builder
-
optional string description = 2;
- setDescription(String) - Method in class alluxio.job.wire.TaskInfo
-
- setDescription(String) - Method in class alluxio.metrics.MetricKey.Builder
-
- setDescriptionBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
-
optional string description = 13;
- setDescriptionBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
-
optional string description = 2;
- setDeviceSpec(String) - Method in class alluxio.util.UnixMountInfo.Builder
-
- setDirectChildrenLoaded(FileSystem, AlluxioURI, boolean) - Static method in class alluxio.cli.fs.command.FileSystemCommandUtils
-
Sets direct children loaded.
- setDirectChildrenLoaded(boolean) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool directChildrenLoaded = 13;
- setDirectChildrenLoaded(Supplier<JournalContext>, InodeDirectory) - Method in class alluxio.master.file.meta.InodeTree
-
Marks an inode directory as having its direct children loaded.
- setDirectChildrenLoaded(Supplier<JournalContext>, InodeDirectory, boolean) - Method in class alluxio.master.file.meta.InodeTree
-
Marks an inode directory as having its direct children loaded or not.
- setDirectChildrenLoaded(boolean) - Method in class alluxio.master.file.meta.MutableInodeDirectory
-
- setDirectChildrenLoaded(boolean) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool direct_children_loaded = 12;
- setDirectChildrenLoaded(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional bool direct_children_loaded = 3;
- setDisableAreDescendantsLoadedCheck(boolean) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
Setting this to true will disable checking during metadata sync to see if the children
of a directory has been loaded.
- setDiskCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets disk capacity.
- setDiskFreeCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets disk free capacity.
- setDiskUsedCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets disk used capacity.
- setDisplayType(PropertyKey.DisplayType) - Method in class alluxio.conf.PropertyKey.Builder
-
- setDomain(JournalDomain) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
optional .alluxio.grpc.journal.JournalDomain domain = 1;
- setDomainSocketPath(String) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string domainSocketPath = 5;
- setDomainSocketPath(String) - Method in class alluxio.wire.WorkerNetAddress
-
- setDomainSocketPathBytes(ByteString) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string domainSocketPath = 5;
- setDoneUnsafe(boolean) - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- setDoneUnsafe(boolean) - Method in class alluxio.worker.grpc.WriteRequestContext
-
- setDoneUnsafe(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
-
- setDoneUnsafe(boolean) - Method in class alluxio.worker.netty.WriteRequestContext
-
- setDoraCacheEnabled(boolean) - Method in class alluxio.client.file.options.FileSystemOptions.Builder
-
- setDoubleStats(DoubleColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- setDoubleStats(DoubleColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- setDoubleType(double) - Method in class alluxio.grpc.table.Value.Builder
-
double double_type = 2;
- setDoubleValue(double) - Method in class alluxio.grpc.MetricValue.Builder
-
optional double doubleValue = 1;
- setDst(String) - Method in class alluxio.grpc.Route.Builder
-
required string dst = 2;
- setDst(String) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string dst = 2;
- setDst(String) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string dst = 2;
- setDstBytes(ByteString) - Method in class alluxio.grpc.Route.Builder
-
required string dst = 2;
- setDstBytes(ByteString) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string dst = 2;
- setDstBytes(ByteString) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string dst = 2;
- setDstPath(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string dstPath = 3;
- setDstPath(String) - Method in class alluxio.grpc.RenamePRequest.Builder
-
the destination path
- setDstPath(AlluxioURI) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
Sets mDstPath field.
- setDstPath(String) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
Deprecated, use new_parent_id/new_name instead
- setDstPathBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string dstPath = 3;
- setDstPathBytes(ByteString) - Method in class alluxio.grpc.RenamePRequest.Builder
-
the destination path
- setDstPathBytes(ByteString) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
Deprecated, use new_parent_id/new_name instead
- setDuration(long) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 duration = 6;
- setDurationMs(long) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- setDurationMs(long) - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- setEmpty(boolean) - Method in class alluxio.security.authorization.DefaultAccessControlList
-
- setEncodingType(String) - Method in class alluxio.s3.ListBucketOptions
-
- setEndMs(long) - Method in class alluxio.stress.client.ClientIOTaskResult
-
- setEndMs(long) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- setEndMs(long) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- setEndTime(long) - Method in class alluxio.master.job.AbstractJob
-
Update end time.
- setEndTime(long) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional int64 end_time = 9;
- setEndTime(long) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional int64 end_time = 8;
- setEndTime(long) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional int64 end_time = 9;
- setEndTimeMs(long) - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- setEnsureAtomic(boolean) - Method in class alluxio.underfs.options.CreateOptions
-
Set atomicity guarantees.
- setEntityTag(FileSystem, AlluxioURI, String) - Static method in class alluxio.proxy.s3.S3RestUtils
-
This helper method is used to set the ETag xAttr on an object.
- setEntityTag(FileSystem, AlluxioURI, String) - Static method in class alluxio.worker.s3.S3NettyHandler
-
This helper method is used to set the ETag xAttr on an object.
- setEntries(int, PAclEntry) - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- setEntries(int, PAclEntry.Builder) - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- setEntries(int, PAclEntry) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- setEntries(int, PAclEntry.Builder) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- setEntries(int, Acl.AclEntry) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- setEntries(int, Acl.AclEntry.Builder) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- setEntry(AclEntry) - Method in class alluxio.security.authorization.AccessControlList
-
Sets an entry into the access control list.
- setEntry(AclEntry) - Method in class alluxio.security.authorization.DefaultAccessControlList
-
- setEntry(AclEntry) - Method in class alluxio.security.authorization.ExtendedACLEntries
-
Sets an entry into the access control list.
- setEntryCount(long) - Method in class alluxio.grpc.BackupPStatus.Builder
-
optional int64 entryCount = 5;
- setEntryCount(long) - Method in class alluxio.wire.BackupStatus
-
Sets entry count.
- setEof(boolean) - Method in class alluxio.grpc.SnapshotData.Builder
-
Deprecated.
- setEof(boolean) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional bool eof = 5;
- setEof(boolean) - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- setEof(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
-
- setEquatable(EquatableValueSet) - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- setEquatable(EquatableValueSet.Builder) - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- setError(Throwable) - Method in class alluxio.thread.AutopsyThread
-
Sets the error before exiting.
- setError(AlluxioException) - Method in class alluxio.wire.BackupStatus
-
Fails the backup with given error.
- setError(Error) - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- setError(Error) - Method in class alluxio.worker.grpc.WriteRequestContext
-
- setError(Error) - Method in class alluxio.worker.netty.ReadRequestContext
-
- setError(Error) - Method in class alluxio.worker.netty.WriteRequestContext
-
- setErrored(List<DeleteObjectsResult.ErrorObject>) - Method in class alluxio.s3.DeleteObjectsResult
-
Sets the set of errored objects in the response.
- setErrorMessage(String) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorMessage = 7;
- setErrorMessage(String) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional string errorMessage = 7;
- setErrorMessage(String) - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorMessage = 2;
- setErrorMessage(String) - Method in class alluxio.job.plan.meta.PlanInfo
-
- setErrorMessage(String) - Method in class alluxio.job.wire.TaskInfo
-
- setErrorMessageBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorMessage = 7;
- setErrorMessageBytes(ByteString) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional string errorMessage = 7;
- setErrorMessageBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorMessage = 2;
- setErrorMsg(String) - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorMsg = 5;
- setErrorMsgBytes(ByteString) - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorMsg = 5;
- setErrors(List<String>) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- setErrors(String, List<String>) - Method in class alluxio.stress.graph.Graph
-
Sets the list of errors for the series.
- setErrors(List<String>) - Method in class alluxio.stress.worker.IOTaskResult
-
- setErrors(List<String>) - Method in class alluxio.stress.worker.IOTaskSummary
-
- setErrors(List<String>) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- setErrorType(String) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorType = 6;
- setErrorType(ErrorType) - Method in class alluxio.grpc.ErrorInfo.Builder
-
optional .alluxio.grpc.ErrorType errorType = 1;
- setErrorType(String) - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorType = 15;
- setErrorType(String) - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorType = 6;
- setErrorType(String) - Method in class alluxio.job.plan.meta.PlanInfo
-
- setErrorType(String) - Method in class alluxio.job.wire.TaskInfo
-
- setErrorTypeBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string errorType = 6;
- setErrorTypeBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorType = 15;
- setErrorTypeBytes(ByteString) - Method in class alluxio.grpc.JobProgress.Builder
-
optional string errorType = 6;
- setETag(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- setETag(String) - Method in class alluxio.proxy.s3.ListPartsResult.Part
-
- setEvictBatchSize(int) - Method in class alluxio.master.metastore.caching.CacheConfiguration.Builder
-
- setEvictionAllowed(boolean) - Method in class alluxio.worker.block.AllocateOptions
-
Sets value for whether eviction is allowed for allocation.
- setEvictorClass(Class<? extends CacheEvictor>) - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
-
- setExcludeMountInfo(boolean) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
Mount info will be excluded from the list status response if this field is set to true.
- setExists(boolean) - Method in class alluxio.grpc.ExistsPResponse.Builder
-
optional bool exists = 1;
- setExists(boolean) - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional bool exists = 3;
- setExpiryMs(long) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional int64 expiryMs = 3;
- setFailedFiles() - Method in class alluxio.cli.fs.command.job.JobAttempt
-
- setFailedNodeInfos(NodeInfo[]) - Method in class alluxio.wire.MasterWebUIWorkers
-
Sets failed node infos.
- setFailures(int, RouteFailure) - Method in class alluxio.grpc.CopyResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- setFailures(int, RouteFailure.Builder) - Method in class alluxio.grpc.CopyResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- setFailures(int, LoadFileFailure) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- setFailures(int, LoadFileFailure.Builder) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
- setFailures(int, RouteFailure) - Method in class alluxio.grpc.MoveResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- setFailures(int, RouteFailure.Builder) - Method in class alluxio.grpc.MoveResponse.Builder
-
repeated .alluxio.grpc.block.RouteFailure failures = 2;
- setFatalError(String) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets fatal error.
- setFatalError(String) - Method in class alluxio.wire.MasterWebUIData
-
Sets fatal error.
- setFatalError(String) - Method in class alluxio.wire.MasterWebUILogs
-
Sets fatal error.
- setFatalError(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Sets fatal error.
- setFatalError(String) - Method in class alluxio.wire.WorkerWebUILogs
-
Sets fatal error.
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ActionInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPStatus.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Block.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockIdList.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockLocation.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockStatus.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BuildVersion.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CacheRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CacheResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Chunk.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClientMetrics.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CmdProgress.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CmdSummary.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Command.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ConfigProperties.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ConfigProperty.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CopyRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CopyResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DeletePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DeletePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DeletePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ErrorInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ExistsPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ExistsPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ExistsPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.File.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileFailure.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemCommand.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FsOpPId.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
Deprecated.
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.InconsistentProperties.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobCommand.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobDescription.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobProgress.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobUnused.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListAllPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterVersion.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Metric.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricValue.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPointInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveBlockResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NetAddress.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PAcl.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PAclEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PersistFile.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PMode.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PolicyInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PolicyStatus.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyStatus.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReadRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReadResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterCommand.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RenamePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RenamePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RenamePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RetryInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Route.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RouteFailure.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunTaskCommand.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SaslMessage.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAclPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAclPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAttributePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SnapshotData.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StatusSummary.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopJobPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopJobPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StorageList.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Constraint.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Database.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Date.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Decimal.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Domain.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Layout.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Partition.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Range.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.RangeSet.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Schema.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TableInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Transformation.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Value.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TierList.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransportMessage.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsFileStatus.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsStatus.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UnmountPOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UnmountPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UnmountPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerIdentity.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
- setFieldRange(Set<GetWorkerReportOptions.WorkerInfoField>) - Method in class alluxio.client.block.options.GetWorkerReportOptions
-
- setFieldRanges(int, WorkerInfoField) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
- setFile(File) - Method in class alluxio.grpc.FileFailure.Builder
-
required .alluxio.grpc.block.File file = 1;
- setFile(File.Builder) - Method in class alluxio.grpc.FileFailure.Builder
-
required .alluxio.grpc.block.File file = 1;
- setFileBlockInfos(int, FileBlockInfo) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- setFileBlockInfos(int, FileBlockInfo.Builder) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
- setFileBlockInfos(List<FileBlockInfo>) - Method in class alluxio.wire.FileInfo
-
- setFileBlocks(List<UIFileBlockInfo>) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets file blocks.
- setFileBlocksOnTier(List<ImmutablePair<String, List<UIFileBlockInfo>>>) - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Sets file blocks on tier.
- setFileBuckets(int) - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- setFileCount(long) - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 fileCount = 2;
- setFileCount(long) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
The total number of files in the listing directory,
(i.e.
- setFileCount(long) - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Set file count.
- setFileData(String) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets file data.
- setFileData(String) - Method in class alluxio.wire.MasterWebUILogs
-
Sets file data.
- setFileData(String) - Method in class alluxio.wire.WorkerWebUILogs
-
Sets file data.
- setFileDatePattern(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string file_date_pattern = 6;
- setFileDatePatternBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string file_date_pattern = 6;
- setFileDoesNotExistException(String) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets file does not exist exception.
- setFileId(long) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 fileId = 1;
- setFileId(long) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
the id of the file
- setFileId(long) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
optional int64 fileId = 1;
- setFileId(long) - Method in class alluxio.grpc.PersistFile.Builder
-
optional int64 fileId = 1;
- setFileId(long) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
optional int64 file_id = 1;
- setFileId(long) - Method in class alluxio.wire.FileInfo
-
- setFileId(long) - Method in class alluxio.wire.PersistFile
-
Set the file id.
- setFileInfo(FileInfo) - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- setFileInfo(FileInfo.Builder) - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- setFileInfo(FileInfo) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- setFileInfo(FileInfo.Builder) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- setFileInfo(FileInfo) - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- setFileInfo(FileInfo.Builder) - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- setFileInfo(FileInfo) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- setFileInfo(FileInfo.Builder) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
- setFileInfos(int, FileInfo) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- setFileInfos(int, FileInfo.Builder) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- setFileInfos(int, FileInfo) - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- setFileInfos(int, FileInfo.Builder) - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
- setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets file infos.
- setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.MasterWebUIData
-
Sets file infos.
- setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.MasterWebUILogs
-
Sets file infos.
- setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Sets file infos.
- setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.WorkerWebUILogs
-
Sets file infos.
- setFileLength(long) - Method in class alluxio.fuse.file.FileStatus
-
Sets the length of the file.
- setFileLocations(List<String>) - Method in class alluxio.util.webui.UIFileInfo
-
Sets file locations.
- setFilePath(String) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string filePath = 4;
- setFilePath(String) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string filePath = 3;
- setFilePath(String) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePath = 3;
- setFilePath(String) - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Set file path.
- setFilePathBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional string filePath = 4;
- setFilePathBytes(ByteString) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string filePath = 3;
- setFilePathBytes(ByteString) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePath = 3;
- setFilePathFailed(String) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePathFailed = 4;
- setFilePathFailedBytes(ByteString) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional string filePathFailed = 4;
- setFileSize(long) - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 fileSize = 3;
- setFileSize(long) - Method in class alluxio.master.job.tracker.CmdRunAttempt
-
Set file size.
- setFilesSkipped(int) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
optional int32 files_skipped = 3;
- setFilesToPersist(List<PersistFile>) - Method in class alluxio.wire.PersistCommandOptions
-
Set the list of files to persist.
- setFileStream(T) - Method in class alluxio.fuse.file.FuseFileEntry
-
- setFileSystemOptions(FileSystemOptions) - Method in class alluxio.fuse.options.FuseOptions.Builder
-
Set file system options.
- setFilter(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string filter = 5;
- setFilter(int, MasterInfoField) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
- setFilter(Job.FileFilter) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- setFilter(Job.FileFilter.Builder) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- setFilter(Job.FileFilter) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- setFilter(Job.FileFilter.Builder) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional .alluxio.proto.journal.FileFilter filter = 12;
- setFilterBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string filter = 5;
- setFilters(int, BlockMasterInfoField) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
- setFirst(T1) - Method in class alluxio.collections.Pair
-
Set the first value.
- setFirst(LockedInodePath) - Method in class alluxio.master.file.meta.InodePathPair
-
- setFlush(boolean) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional bool flush = 5;
- setFolder(boolean) - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool folder = 9;
- setFolder(boolean) - Method in class alluxio.wire.FileInfo
-
- setForced(boolean) - Method in class alluxio.grpc.FreePOptions.Builder
-
optional bool forced = 2;
- setForceLocation(boolean) - Method in class alluxio.worker.block.AllocateOptions
-
Sets value for whether to enforce location of allocation.
- setForkJoinTaskTag(short) - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Atomically sets the tag value for this task and returns the old value.
- setFormat(JobProgressReportFormat) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
- setFormat(JobProgressReportFormat) - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
- setFreeBytes(long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 freeBytes = 3;
- setFreeBytes(long) - Method in class alluxio.wire.BlockMasterInfo
-
- setFreeCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets free capacity.
- setFreeCapacityBytes(long) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set free capacity in bytes.
- setFromUFSFallBack() - Method in class alluxio.client.file.URIStatus
-
Sets flag that the FileInfo is retrieved from UFS instead of worker.
- setFsType(String) - Method in class alluxio.util.UnixMountInfo.Builder
-
- setFuseMountOptions(Set<String>) - Method in class alluxio.fuse.options.FuseOptions.Builder
-
Sets mount options.
- setFuseStreamFactory(FuseStreamFactory) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- setGainPrimacyTime(String) - Method in class alluxio.wire.MasterInfo
-
- setGainPrimacyTimeMs(long) - Method in class alluxio.wire.MasterInfo
-
- setGcExecutor(ScheduledExecutorService) - Method in class alluxio.resource.DynamicResourcePool.Options
-
- setGcIntervalMs(long) - Method in class alluxio.resource.DynamicResourcePool.Options
-
- setGroup(String) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setGroup(String) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string group = 17;
- setGroup(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string group = 4;
- setGroup(String) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string group = 5;
- setGroup(String) - Method in class alluxio.master.file.contexts.CreatePathContext
-
- setGroup(String) - Method in class alluxio.master.file.meta.MutableInode
-
- setGroup(String) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string group = 3;
- setGroup(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string group = 9;
- setGroup(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string group = 15;
- setGroup(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string group = 7;
- setGroup(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string group = 10;
- setGroup(String) - Method in class alluxio.underfs.options.CreateOptions
-
- setGroup(String) - Method in class alluxio.underfs.options.MkdirsOptions
-
- setGroup(String) - Method in class alluxio.wire.FileInfo
-
- setGroupActions(int, Acl.NamedAclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- setGroupActions(int, Acl.NamedAclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
- setGroupBits(Bits) - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits groupBits = 2;
- setGroupBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
-
Sets group bits.
- setGroupBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string group = 17;
- setGroupBytes(ByteString) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string group = 4;
- setGroupBytes(ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string group = 5;
- setGroupBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string group = 3;
- setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string group = 9;
- setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string group = 15;
- setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string group = 7;
- setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string group = 10;
- setHandler(AbstractHandler) - Method in class alluxio.web.WebServer
-
- setHasDirectChildrenLoaded(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool has_direct_children_loaded = 13;
- setHigh(Value) - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value high = 2;
- setHigh(Value.Builder) - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value high = 2;
- setHighestTierAlias(String) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets highest tier alias.
- setHighValue(Date) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date high_value = 2;
- setHighValue(Date.Builder) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date high_value = 2;
- setHighValue(Decimal) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- setHighValue(Decimal.Builder) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal high_value = 2;
- setHighValue(double) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional double high_value = 2;
- setHighValue(long) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 high_value = 2;
- setHighWaterMark(int) - Method in class alluxio.master.metastore.caching.CacheConfiguration.Builder
-
- setHiveCacheContext(HiveCacheContext) - Method in class alluxio.client.file.CacheContext
-
- setHost(String) - Method in class alluxio.grpc.NetAddress.Builder
-
optional string host = 1;
- setHost(String) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string host = 1;
- setHost(String) - Method in class alluxio.wire.Address
-
- setHost(String) - Method in class alluxio.wire.WorkerNetAddress
-
- setHostBytes(ByteString) - Method in class alluxio.grpc.NetAddress.Builder
-
optional string host = 1;
- setHostBytes(ByteString) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string host = 1;
- setHostname(String) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional string hostname = 4;
- setHostname() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Sets hostname.
- setHostname(String) - Method in class alluxio.wire.BackupStatus
-
Sets the backup host.
- setHostnameBytes(ByteString) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional string hostname = 4;
- setId(long) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
optional int64 id = 1;
- setId(int) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional uint32 id = 1;
- setId(long) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
The block ID or UFS file ID.
- setId(long) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
The block ID or UFS file ID.
- setId(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 id = 2;
- setId(long) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 id = 1;
- setId(long) - Method in class alluxio.wire.MasterInfo
-
- setId(long) - Method in class alluxio.wire.WorkerInfo
-
- setIdentifier(ByteString) - Method in class alluxio.grpc.WorkerIdentity.Builder
-
exactly how this byte sequence is interpreted depends on the version of its definition
- setIgnoreClusterConf(boolean) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool ignoreClusterConf = 2;
- setIgnoredSiteProperty(boolean) - Method in class alluxio.conf.PropertyKey.Builder
-
- setIgnorePathConf(boolean) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool ignorePathConf = 3;
- setIgnoreSyncErrors(boolean) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional bool ignore_sync_errors = 6;
- setInAlluxioFileNum(int) - Method in class alluxio.wire.MasterWebUIData
-
Sets in alluxio file num.
- setInAlluxioPercentage(int) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 inAlluxioPercentage = 24;
- setInAlluxioPercentage(int) - Method in class alluxio.wire.FileInfo
-
- setIncludeRealContentHash(boolean) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional bool includeRealContentHash = 5;
- setIncludeRealContentHash(boolean) - Method in class alluxio.underfs.options.GetStatusOptions
-
- setInconsistentPaths(int, String) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
repeated string inconsistentPaths = 1;
- setIndex(int) - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- setInfo(int, TransformJobInfo) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- setInfo(int, TransformJobInfo.Builder) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
- setInfos(int, ActionInfo) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- setInfos(int, ActionInfo.Builder) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
- setInitialBytes(long) - Method in class alluxio.worker.block.CreateBlockOptions
-
- setInitialDelayMs(long) - Method in class alluxio.resource.DynamicResourcePool.Options
-
- setInitiated(String) - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
-
- setInMemoryPercentage(int) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 inMemoryPercentage = 25;
- setInMemoryPercentage(int) - Method in class alluxio.wire.FileInfo
-
- setInodeDirectory(File.InodeDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- setInodeDirectory(File.InodeDirectoryEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
- setInodeDirectoryIdGenerator(File.InodeDirectoryIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- setInodeDirectoryIdGenerator(File.InodeDirectoryIdGeneratorEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
- setInodeFile(File.InodeFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- setInodeFile(File.InodeFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
- setInodeLastModificationTime(File.InodeLastModificationTimeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- setInodeLastModificationTime(File.InodeLastModificationTimeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
- setInodeStoreFactory(InodeStore.Factory) - Method in class alluxio.master.CoreMasterContext.Builder
-
- setInputFormat(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string input_format = 2;
- setInputFormatBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string input_format = 2;
- setInstance(String) - Method in class alluxio.grpc.Metric.Builder
-
optional string instance = 1;
- setInstanceBytes(ByteString) - Method in class alluxio.grpc.Metric.Builder
-
optional string instance = 1;
- setInternalAcl(AccessControlList) - Method in class alluxio.master.file.meta.MutableInode
-
Sets the internal ACL to a specified ACL.
- setInterval(int) - Method in class alluxio.util.WaitForOptions
-
- setInvalidPathError(String) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets invalid path error.
- setInvalidPathError(String) - Method in class alluxio.wire.MasterWebUILogs
-
Sets invalid path error.
- setInvalidPathError(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Sets invalid path error.
- setInvalidPathError(String) - Method in class alluxio.wire.WorkerWebUILogs
-
Sets invalid path error.
- setInvalidPathException(String) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets invalid path exception.
- setIOBytes(long) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- setIOBytes(long) - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- setIOBytes(long) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- setIOMBps(float) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- setIOMBps(float) - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- setIp(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
Sets mIp field.
- setIp(String) - Method in class alluxio.master.job.JobMasterAuditContext
-
Sets mIp field.
- setIp(String) - Method in class alluxio.s3.S3AuditContext
-
Sets mIp field.
- setIsAsyncWriteEnabled(boolean) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setIsAtomicWrite(boolean) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool isAtomicWrite = 16;
- setIsBuiltIn(boolean) - Method in class alluxio.conf.PropertyKey.Builder
-
- setIsCacheable(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_cacheable = 17;
- setIsClusterAggregated(boolean) - Method in class alluxio.metrics.MetricKey.Builder
-
- setIsCompleted(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_completed = 18;
- setIsDefault(boolean) - Method in class alluxio.grpc.PAcl.Builder
-
optional bool isDefault = 5;
- setIsDefault(boolean) - Method in class alluxio.grpc.PAclEntry.Builder
-
optional bool isDefault = 4;
- setIsDefault(boolean) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional bool isDefault = 7;
- setIsDefault(boolean) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional bool isDefault = 4;
- setIsDefault(boolean) - Method in class alluxio.security.authorization.AclEntry.Builder
-
Set this AclEntry to be for default ACL.
- setIsDefaultEmpty(boolean) - Method in class alluxio.grpc.PAcl.Builder
-
optional bool isDefaultEmpty = 6;
- setIsDirectory(boolean) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional bool is_directory = 2;
- setIsDirectory(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_directory = 3;
- setIsDynamic(boolean) - Method in class alluxio.conf.PropertyKey.Builder
-
- setIsEmpty(boolean) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional bool isEmpty = 8;
- setIsHidden(boolean) - Method in class alluxio.conf.PropertyKey.Builder
-
- setIsLeader(boolean) - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional bool isLeader = 3;
- setIsMountPoint(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
directory only
- setIsMultipartUpload(boolean) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
optional bool isMultipartUpload = 2;
- setIsNondeterministic(boolean) - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
-
- setIsPinned(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional bool is_pinned = 9;
- setIsRetryable(boolean) - Method in class alluxio.grpc.RetryInfo.Builder
-
optional bool isRetryable = 1;
- setIsScanning(boolean) - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional bool isScanning = 11;
- setIsSkip(boolean) - Method in class alluxio.grpc.RouteFailure.Builder
-
optional bool is_skip = 5;
- setIsThrowable(boolean) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
optional bool isThrowable = 2;
- setIsTruncated(boolean) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
True if the partial listing was truncated.
- setIsTruncated(boolean) - Method in class alluxio.proxy.s3.ListPartsResult
-
- setJob(Job) - Method in class alluxio.scheduler.job.Task
-
Set the job.
- setJobAsFailed(String, String) - Method in class alluxio.master.job.plan.PlanCoordinator
-
Sets the job as failed with given error message.
- setJobConfig(ByteString) - Method in class alluxio.grpc.RunPRequest.Builder
-
optional bytes jobConfig = 1;
- setJobConfig(ByteString) - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional bytes jobConfig = 3;
- setJobConfigAndFileMetrics(List<Pair<String, String>>, boolean, WriteType, CmdRunAttempt) - Method in class alluxio.master.job.tracker.MigrateCliRunner
-
Create a JobConfig and set file count and size for the Migrate job.
- setJobControlId(long) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
optional int64 jobControlId = 1;
- setJobControlId(long) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 jobControlId = 1;
- setJobControlId(long) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional int64 jobControlId = 1;
- setJobControlId(long) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional int64 jobControlId = 1;
- setJobControlId(long) - Method in class alluxio.grpc.SubmitResponse.Builder
-
optional int64 jobControlId = 1;
- setJobDescription(JobDescription) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- setJobDescription(JobDescription.Builder) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- setJobDescription(JobDescription) - Method in class alluxio.grpc.StopJobPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- setJobDescription(JobDescription.Builder) - Method in class alluxio.grpc.StopJobPRequest.Builder
-
required .alluxio.grpc.file.JobDescription jobDescription = 1;
- setJobError(String) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string job_error = 6;
- setJobErrorBytes(ByteString) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string job_error = 6;
- setJobId(long) - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional int64 jobId = 1;
- setJobId(long) - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
optional int64 jobId = 1;
- setJobId(long) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional int64 jobId = 1;
- setJobId(long) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional int64 jobId = 1;
- setJobId(long) - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 jobId = 1;
- setJobId(long) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional int64 jobId = 1;
- setJobId(long) - Method in class alluxio.grpc.RunPResponse.Builder
-
optional int64 jobId = 1;
- setJobId(long) - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional int64 jobId = 1;
- setJobId(String) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
optional string jobId = 1;
- setJobId(long) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
optional int64 job_id = 1;
- setJobId(long) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional int64 job_id = 4;
- setJobId(long) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
optional int64 job_id = 1;
- setJobId(long) - Method in class alluxio.job.wire.TaskInfo
-
- setJobId(long) - Method in class alluxio.master.job.JobMasterAuditContext
-
Sets mCreationTimeNs field.
- setJobId(String) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string job_id = 8;
- setJobId(String) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string job_id = 7;
- setJobId(String) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string job_id = 8;
- setJobIdBytes(ByteString) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
optional string jobId = 1;
- setJobIdBytes(ByteString) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string job_id = 8;
- setJobIdBytes(ByteString) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string job_id = 7;
- setJobIdBytes(ByteString) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string job_id = 8;
- setJobIdOnly(boolean) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional bool jobIdOnly = 3;
- setJobIds(int, long) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated int64 jobIds = 1;
- setJobInfo(JobInfo) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- setJobInfo(JobInfo.Builder) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- setJobInfo(JobInfo) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- setJobInfo(JobInfo.Builder) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- setJobInfos(int, JobInfo) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- setJobInfos(int, JobInfo.Builder) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- setJobMasterId(long) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional int64 jobMasterId = 1;
- setJobMasterStatus(int, JobMasterStatus) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- setJobMasterStatus(int, JobMasterStatus.Builder) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
- setJobName(String) - Method in class alluxio.master.job.JobMasterAuditContext
-
Sets mJobName field.
- setJobProgress(int, JobProgress) - Method in class alluxio.grpc.CmdProgress.Builder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- setJobProgress(int, JobProgress.Builder) - Method in class alluxio.grpc.CmdProgress.Builder
-
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
- setJobSource(JobSource) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.JobSource jobSource = 3;
- setJobState(JobState, boolean) - Method in class alluxio.master.job.AbstractJob
-
Set load state.
- setJobState(JobState, boolean) - Method in interface alluxio.scheduler.job.Job
-
set job state.
- setJobStatus(Status) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
optional .alluxio.grpc.job.Status jobStatus = 2;
- setJobStatus(Status) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional .alluxio.grpc.job.Status job_status = 5;
- setJobStatusBlock(int, JobStatusBlock) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- setJobStatusBlock(int, JobStatusBlock.Builder) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
- setJobStopped(boolean) - Method in class alluxio.grpc.StopJobPResponse.Builder
-
optional bool jobStopped = 1;
- setJobSuccess() - Method in class alluxio.master.job.CopyJob
-
- setJobSuccess() - Method in class alluxio.master.job.DoraLoadJob
-
- setJobSuccess() - Method in class alluxio.master.job.LoadJob
-
- setJobSuccess() - Method in class alluxio.master.job.MoveJob
-
- setJobSuccess() - Method in interface alluxio.scheduler.job.Job
-
set job as success.
- setJobWorkerHealth(JobWorkerHealth) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- setJobWorkerHealth(JobWorkerHealth.Builder) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
- setJournalCheckpointTimeWarning(String) - Method in class alluxio.wire.MasterWebUIOverview
-
- setJournalDiskMetrics(List<JournalDiskInfo>) - Method in class alluxio.wire.MasterWebUIMetrics
-
- setJournalDiskWarnings(List<String>) - Method in class alluxio.wire.MasterWebUIOverview
-
- setJournalEntries(int, Journal.JournalEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
This journal entry is a list of other entries.
- setJournalEntries(int, Journal.JournalEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
This journal entry is a list of other entries.
- setJournalEntriesSinceCheckpoint(long) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
optional int64 journalEntriesSinceCheckpoint = 2;
- setJournalEntriesSinceCheckpoint(long) - Method in class alluxio.master.meta.MasterInfo
-
- setJournalEntriesSinceCheckpoint(long) - Method in class alluxio.wire.MasterInfo
-
- setJournalEntriesSinceCheckpoint(long) - Method in class alluxio.wire.MasterWebUIMetrics
-
- setJournalLastCheckpointTime(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
- setJournalSystem(JournalSystem) - Method in class alluxio.master.CoreMasterContext.Builder
-
- setKeepAliveClient(CloseableClient) - Method in class alluxio.membership.DefaultServiceEntity
-
Set keep alive client.
- setKey(BlockStoreLocationProto) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- setKey(BlockStoreLocationProto.Builder) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
- setKey(PropertyKey) - Method in class alluxio.master.meta.checkconf.ConfigRecord
-
- setKey(String) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string key = 1;
- setKey(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest.Part
-
- setKey(int) - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest.Part
-
- setKey(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- setKey(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
-
- setKey(String) - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
-
- setKey(String) - Method in class alluxio.proxy.s3.ListPartsResult
-
- setKey(String) - Method in class alluxio.s3.DeleteObjectsRequest.DeleteObject
-
Sets the key to the object.
- setKey(String) - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
-
Sets the key of successfully deleted object.
- setKey(String) - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
-
Sets the key of error object.
- setKeyBytes(ByteString) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string key = 1;
- setKeys(int, String) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
repeated string keys = 2;
- setLastAccessedMs(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 last_accessed_ms = 30;
- setLastAccessTimeMs(long) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 lastAccessTimeMs = 31;
- setLastAccessTimeMs(long) - Method in class alluxio.master.file.meta.MutableInode
-
- setLastAccessTimeMs(long, boolean) - Method in class alluxio.master.file.meta.MutableInode
-
- setLastAccessTimeMs(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 last_access_time_ms = 20;
- setLastAccessTimeMs(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 last_access_time_ms = 29;
- setLastAccessTimeMs(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 last_access_time_ms = 18;
- setLastAccessTimeMs(long) - Method in class alluxio.resource.DynamicResourcePool.ResourceInternal
-
- setLastAccessTimeMs(long) - Method in class alluxio.wire.FileInfo
-
- setLastCheckpointTime(long) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
optional int64 lastCheckpointTime = 1;
- setLastCheckpointTime(String) - Method in class alluxio.wire.MasterInfo
-
- setLastCheckpointTimeMs(long) - Method in class alluxio.master.meta.MasterInfo
-
- setLastCheckpointTimeMs(long) - Method in class alluxio.wire.MasterInfo
-
- setLastContactSec(int) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int32 lastContactSec = 3;
- setLastContactSec(int) - Method in class alluxio.wire.WorkerInfo
-
- setLastHeartbeatTime(long) - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional int64 lastHeartbeatTime = 4;
- setLastModificationTimeMs(long) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 lastModificationTimeMs = 14;
- setLastModificationTimeMs(long) - Method in class alluxio.master.file.meta.MutableInode
-
Sets the last modification time of the inode to the new time if the new time is more recent.
- setLastModificationTimeMs(long, boolean) - Method in class alluxio.master.file.meta.MutableInode
-
- setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
optional int64 last_modification_time_ms = 2;
- setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 last_modification_time_ms = 7;
- setLastModificationTimeMs(long) - Method in class alluxio.wire.FileInfo
-
- setLastModified(String) - Method in class alluxio.proxy.s3.ListPartsResult.Part
-
- setLastModifiedMs(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 last_modified_ms = 25;
- setLastModifiedTimeMs(long) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional int64 last_modified_time_ms = 3;
- setLastUpdated(long) - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 lastUpdated = 6;
- setLastUpdated(long) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int64 lastUpdated = 3;
- setLastUpdatedTime(long) - Method in class alluxio.grpc.ActionInfo.Builder
-
optional int64 lastUpdatedTime = 5;
- setLastUpdatedTime(String) - Method in class alluxio.wire.MasterInfo
-
- setLastUpdatedTimeMs(long) - Method in class alluxio.wire.MasterInfo
-
- setLastUpdateMs(long) - Method in class alluxio.grpc.JobProgress.Builder
-
optional int64 lastUpdateMs = 4;
- setLatest(SnapshotMetadata) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- setLatest(SnapshotMetadata.Builder) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- setLayout(Layout) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Layout layout = 6;
- setLayout(Layout.Builder) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Layout layout = 6;
- setLayout(Layout) - Method in class alluxio.grpc.table.Transformation.Builder
-
optional .alluxio.grpc.table.Layout layout = 1;
- setLayout(Layout.Builder) - Method in class alluxio.grpc.table.Transformation.Builder
-
optional .alluxio.grpc.table.Layout layout = 1;
- setLayoutData(ByteString) - Method in class alluxio.grpc.table.Layout.Builder
-
optional bytes layout_data = 3;
- setLayoutSpec(LayoutSpec) - Method in class alluxio.grpc.table.Layout.Builder
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- setLayoutSpec(LayoutSpec.Builder) - Method in class alluxio.grpc.table.Layout.Builder
-
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
- setLayoutType(String) - Method in class alluxio.grpc.table.Layout.Builder
-
optional string layout_type = 1;
- setLayoutTypeBytes(ByteString) - Method in class alluxio.grpc.table.Layout.Builder
-
optional string layout_type = 1;
- setLeaderId(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets the leader id.
- setLeaderMasterAddress(String) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string leaderMasterAddress = 1;
- setLeaderMasterAddressBytes(ByteString) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string leaderMasterAddress = 1;
- setLease(AlluxioEtcdClient.Lease) - Method in class alluxio.membership.DefaultServiceEntity
-
Set lease.
- setLeaseTimeoutInSec(long) - Method in class alluxio.membership.DefaultServiceEntity
-
Set the timeout for lease in seconds.
- setLeaseTTLInSec(long) - Method in class alluxio.membership.DefaultServiceEntity
-
Set the TTL for lease in seconds.
- setLeastSignificantBits(long) - Method in class alluxio.grpc.FsOpPId.Builder
-
optional int64 leastSignificantBits = 2;
- setLeastSignificantBits(long) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
optional int64 leastSignificantBits = 2;
- setLength(long) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int64 length = 5;
- setLength(long) - Method in class alluxio.grpc.Block.Builder
-
The block length.
- setLength(long) - Method in class alluxio.grpc.BlockInfo.Builder
-
optional int64 length = 2;
- setLength(long) - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int64 length = 5;
- setLength(long) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the length of the block being committed
- setLength(long) - Method in class alluxio.grpc.File.Builder
-
file length
- setLength(long) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 length = 5;
- setLength(long) - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 length = 3;
- setLength(long) - Method in class alluxio.grpc.Route.Builder
-
optional int64 length = 3;
- setLength(long) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setLength(long) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int64 length = 5;
- setLength(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 length = 3;
- setLength(long) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
optional int64 length = 2;
- setLength(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 length = 3;
- setLength(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 length = 9;
- setLength(long) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 length = 2;
- setLength(long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 length = 3;
- setLength(long) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
optional int64 length = 1;
- setLength(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 length = 19;
- setLength(long) - Method in class alluxio.underfs.options.OpenOptions
-
- setLength(long) - Method in class alluxio.wire.BlockInfo
-
- setLength(long) - Method in class alluxio.wire.FileInfo
-
- setLevel(String) - Method in class alluxio.wire.LogInfo
-
- setLFULogBase(double) - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
-
- setListType(Integer) - Method in class alluxio.s3.ListBucketOptions
-
- setLiveWorkerNodes(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets live worker nodes.
- setLiveWorkerNum(int) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 liveWorkerNum = 4;
- setLiveWorkerNum(int) - Method in class alluxio.wire.BlockMasterInfo
-
- setLiveWorkers(int) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set live workers.
- setLoadAverage(int, double) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
repeated double loadAverage = 2;
- setLoadDescendantType(LoadDescendantPType) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
- setLoadDirectChildren(boolean) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
This is deprecated since 1.1.1 and will be removed in 2.0.
- setLoadJob(Job.LoadJobEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- setLoadJob(Job.LoadJobEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
- setLoadMetadataOnly(boolean) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
No data will be transferred.
- setLoadMetadataOnly(boolean) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
If set false, only the metadata of file will be loaded.
- setLoadMetadataOnly(boolean) - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool loadMetadataOnly = 4;
- setLoadMetadataOnly(boolean) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional bool load_metadata_only = 9;
- setLoadMetadataType(LoadMetadataPType) - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- setLoadMetadataType(LoadMetadataPType) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
- setLoadMetadataType(LoadMetadataPType) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
- setLoadPath(String) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string load_path = 1;
- setLoadPathBytes(ByteString) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required string load_path = 1;
- setLoadType(LoadMetadataPType) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
- setLocalDirStickyBit(String) - Static method in class alluxio.util.io.FileUtils
-
Sticky bit can be set primarily on directories in UNIX / Linux.
- setLocalFileSystem(boolean) - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool localFileSystem = 1;
- setLocation(String) - Method in class alluxio.grpc.table.Database.Builder
-
optional string location = 3;
- setLocation(String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional string location = 2;
- setLocation(URI) - Method in class alluxio.master.journal.JournalSystem.Builder
-
- setLocation(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- setLocation(BlockStoreLocation) - Method in class alluxio.worker.block.AllocateOptions
-
Sets the allocation location.
- setLocationBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
-
optional string location = 3;
- setLocationBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional string location = 2;
- setLocations(int, BlockLocation) - Method in class alluxio.grpc.BlockInfo.Builder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- setLocations(int, BlockLocation.Builder) - Method in class alluxio.grpc.BlockInfo.Builder
-
repeated .alluxio.grpc.BlockLocation locations = 3;
- setLocations(List<BlockLocation>) - Method in class alluxio.wire.BlockInfo
-
- setLogLevel(String, String) - Static method in class alluxio.util.LogUtils
-
Gets a logger's level with specify name, if the level argument is not null, it will set to
specify level first.
- setLogName(String) - Method in class alluxio.wire.LogInfo
-
- setLongestRunning(int, JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- setLongestRunning(int, JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
- setLongestRunningJobs(List<JobServiceOutput.SerializableJobInfo>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Set the longest running jobs.
- setLongStats(LongColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- setLongStats(LongColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- setLongType(long) - Method in class alluxio.grpc.table.Value.Builder
-
int64 long_type = 1;
- setLosePrimacyTime(String) - Method in class alluxio.wire.MasterInfo
-
- setLosePrimacyTimeMs(long) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional int64 losePrimacyTimeMs = 3;
- setLosePrimacyTimeMs(long) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional int64 losePrimacyTimeMs = 3;
- setLosePrimacyTimeMs(long) - Method in class alluxio.master.meta.JobMasterInfo
-
- setLosePrimacyTimeMs(long) - Method in class alluxio.master.meta.MasterInfo
-
- setLosePrimacyTimeMs(long) - Method in class alluxio.wire.MasterInfo
-
- setLostMasterInfos(MasterInfo[]) - Method in class alluxio.wire.MasterWebUIMasters
-
Sets lost master infos.
- setLostWorkerNum(int) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int32 lostWorkerNum = 5;
- setLostWorkerNum(int) - Method in class alluxio.wire.BlockMasterInfo
-
- setLostWorkers(int) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set lost workers.
- setLostWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setLow(Value) - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value low = 1;
- setLow(Value.Builder) - Method in class alluxio.grpc.table.Range.Builder
-
optional .alluxio.grpc.table.Value low = 1;
- setLowValue(Date) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date low_value = 1;
- setLowValue(Date.Builder) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional .alluxio.grpc.table.Date low_value = 1;
- setLowValue(Decimal) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- setLowValue(Decimal.Builder) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional .alluxio.grpc.table.Decimal low_value = 1;
- setLowValue(double) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional double low_value = 1;
- setLowValue(long) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 low_value = 1;
- setLowWaterMark(int) - Method in class alluxio.master.metastore.caching.CacheConfiguration.Builder
-
- setMarker(String) - Method in class alluxio.s3.ListBucketOptions
-
- setMaskActions(Acl.AclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- setMaskActions(Acl.AclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions maskActions = 5;
- setMasterAddress(String) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set master address.
- setMasterAddress(NetAddress) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- setMasterAddress(NetAddress.Builder) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- setMasterAddress(NetAddress) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- setMasterAddress(NetAddress.Builder) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 1;
- setMasterAddress(NetAddress) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- setMasterAddress(NetAddress.Builder) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.NetAddress masterAddress = 2;
- setMasterAddresses(int, NetAddress) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- setMasterAddresses(int, NetAddress.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
- setMasterCapacityFreePercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets master capacity free percentage.
- setMasterCapacityUsedPercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets master capacity used percentage.
- setMasterHostname(String) - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
The hostname of the master that did the checkpoint
- setMasterHostname(String) - Method in class alluxio.wire.WorkerWebUIInit
-
Sets master ip.
- setMasterHostnameBytes(ByteString) - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
The hostname of the master that did the checkpoint
- setMasterId(long) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
optional int64 masterId = 1;
- setMasterId(long) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
optional int64 masterId = 1;
- setMasterId(long) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional int64 masterId = 1;
- setMasterId(long) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional int64 masterId = 1;
- setMasterId(long) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional int64 masterId = 1;
- setMasterInfo(MasterInfo) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- setMasterInfo(MasterInfo.Builder) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
- setMasterInquireClient(MasterInquireClient) - Method in class alluxio.master.MasterClientContextBuilder
-
- setMasterNodeAddress(String) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets master node address.
- setMasterNodeAddress(String) - Method in class alluxio.wire.MasterWebUIData
-
Sets master node address.
- setMasterNodeAddress(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets master node address.
- setMasterPort(int) - Method in class alluxio.wire.WorkerWebUIInit
-
Sets master port.
- setMasterProperties(Map<Integer, Map<PropertyKey, String>>) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
-
Sets master specific properties.
- setMasterRole(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets the master role name.
- setMasterStatus(List<JobServiceOutput.SerializableJobMasterStatus>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Set master status.
- setMasterUnderfsCapacityFreePercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets master underfs capacity free percentage.
- setMasterUnderfsCapacityUsedPercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets master underfs capacity used percentage.
- setMasterVersions(List<SummaryOutput.SerializableMasterVersion>) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set master versions.
- setMasterVersions(int, MasterVersion) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- setMasterVersions(int, MasterVersion.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
- setMaxCapacity(int) - Method in class alluxio.resource.DynamicResourcePool.Options
-
- setMaxColLen(long) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional int64 max_col_len = 1;
- setMaxColLen(long) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 max_col_len = 1;
- setMaxEvictionRetries(int) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setMaxKeys(int) - Method in class alluxio.s3.ListBucketOptions
-
- setMaxSize(int) - Method in class alluxio.master.metastore.caching.CacheConfiguration.Builder
-
- setMaxUfsReadConcurrency(int) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional int32 maxUfsReadConcurrency = 2;
- setMaxUfsReadConcurrency(int) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional int32 maxUfsReadConcurrency = 4;
- setMedium(String) - Method in class alluxio.worker.block.CreateBlockOptions
-
- setMediumType(String) - Method in class alluxio.client.file.options.OutStreamOptions
-
Set the write medium type of the file.
- setMediumType(String) - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string mediumType = 4;
- setMediumType(String) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string mediumType = 2;
- setMediumType(String) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional string mediumType = 7;
- setMediumType(int, String) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated string mediumType = 33;
- setMediumType(String) - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional string medium_type = 2;
- setMediumType(String) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional string medium_type = 8;
- setMediumType(int, String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
repeated string medium_type = 18;
- setMediumType(int, String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated string medium_type = 26;
- setMediumType(int, String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
repeated string medium_type = 16;
- setMediumType(String) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string mediumType = 3;
- setMediumType(int, String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated string medium_type = 27;
- setMediumType(String) - Method in class alluxio.wire.BlockLocation
-
- setMediumTypeBytes(ByteString) - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string mediumType = 4;
- setMediumTypeBytes(ByteString) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string mediumType = 2;
- setMediumTypeBytes(ByteString) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional string mediumType = 7;
- setMediumTypeBytes(ByteString) - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional string medium_type = 2;
- setMediumTypeBytes(ByteString) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional string medium_type = 8;
- setMediumTypeBytes(ByteString) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string mediumType = 3;
- setMediumTypes(ImmutableSet<String>) - Method in class alluxio.master.file.meta.MutableInode
-
- setMediumTypes(Set<String>) - Method in class alluxio.wire.FileInfo
-
- setMessage(String) - Method in class alluxio.grpc.BlockStatus.Builder
-
A developer-facing error message
- setMessage(String) - Method in class alluxio.grpc.FileFailure.Builder
-
A developer-facing error message
- setMessage(String) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
A developer-facing error message
- setMessage(String) - Method in class alluxio.grpc.RouteFailure.Builder
-
A developer-facing error message
- setMessage(ByteString) - Method in class alluxio.grpc.SaslMessage.Builder
-
optional bytes message = 2;
- setMessage(ByteString) - Method in class alluxio.grpc.TransportMessage.Builder
-
optional bytes message = 3;
- setMessage(String) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional string message = 2;
- setMessage(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- setMessage(String) - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
-
Sets the error message of this result.
- setMessage(String) - Method in class alluxio.s3.S3Error
-
- setMessage(String) - Method in class alluxio.wire.LogInfo
-
- setMessageBytes(ByteString) - Method in class alluxio.grpc.BlockStatus.Builder
-
A developer-facing error message
- setMessageBytes(ByteString) - Method in class alluxio.grpc.FileFailure.Builder
-
A developer-facing error message
- setMessageBytes(ByteString) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
A developer-facing error message
- setMessageBytes(ByteString) - Method in class alluxio.grpc.RouteFailure.Builder
-
A developer-facing error message
- setMessageBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional string message = 2;
- setMessageCompression(boolean) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
-
- setMessageType(SaslMessageType) - Method in class alluxio.grpc.SaslMessage.Builder
-
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
- setMetadataCacheEnabled(boolean) - Method in class alluxio.client.file.options.FileSystemOptions.Builder
-
- setMetadataLoad(boolean) - Method in class alluxio.master.file.contexts.CompleteFileContext
-
- setMetadataLoad(boolean) - Method in class alluxio.master.file.contexts.CreatePathContext
-
- setMetadataLoad(boolean) - Method in class alluxio.master.file.contexts.DeleteContext
-
- setMetadataLoad(boolean) - Method in class alluxio.master.file.contexts.SetAttributeContext
-
- setMeter(Meter) - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- setMeter(Meter) - Method in class alluxio.worker.grpc.WriteRequestContext
-
- setMetrics(int, Metric) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- setMetrics(int, Metric.Builder) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- setMetrics(int, Metric) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- setMetrics(int, Metric.Builder) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- setMetrics(Map<String, Long>) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setMetrics(Map<String, Long>) - Method in class alluxio.wire.AlluxioWorkerInfo
-
- setMetricsInfo(List<MetricsOutput.SerializableMetricInfo>) - Method in class alluxio.cli.fsadmin.report.MetricsOutput
-
Set metrics info.
- setMetricType(MetricType) - Method in class alluxio.grpc.Metric.Builder
-
required .alluxio.grpc.MetricType metricType = 5;
- setMetricType(MetricType) - Method in class alluxio.grpc.MetricValue.Builder
-
optional .alluxio.grpc.MetricType metricType = 6;
- setMetricType(MetricType) - Method in class alluxio.metrics.MetricKey.Builder
-
- setMinCapacity(int) - Method in class alluxio.resource.DynamicResourcePool.Options
-
- setMode(Mode) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setMode(String, short) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- setMode(PMode) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- setMode(PMode.Builder) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- setMode(PMode) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- setMode(PMode.Builder) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 3;
- setMode(int) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 mode = 18;
- setMode(int) - Method in class alluxio.grpc.PAcl.Builder
-
optional int32 mode = 4;
- setMode(PMode) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 5;
- setMode(PMode.Builder) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.PMode mode = 5;
- setMode(int) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional int32 mode = 6;
- setMode(short) - Method in class alluxio.master.file.meta.MutableInode
-
- setMode(int) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional int32 mode = 4;
- setMode(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int32 mode = 10;
- setMode(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 mode = 16;
- setMode(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int32 mode = 11;
- setMode(short) - Method in class alluxio.security.authorization.AccessControlList
-
Sets permitted actions for owning user, owning group, and other based on the mode.
- setMode(String, short) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
-
- setMode(String, short) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
-
- setMode(String, short) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- setMode(String, short) - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- setMode(String, short) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- setMode(String, short) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- setMode(String, short) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- setMode(String, short) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- setMode(String, short) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- setMode(Mode) - Method in class alluxio.underfs.options.CreateOptions
-
- setMode(Mode) - Method in class alluxio.underfs.options.MkdirsOptions
-
- setMode(String, short) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- setMode(String, short) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- setMode(String, short) - Method in interface alluxio.underfs.UnderFileSystem
-
Changes posix file mode.
- setMode(String, short) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- setMode(int) - Method in class alluxio.wire.FileInfo
-
- setMostSignificantBits(long) - Method in class alluxio.grpc.FsOpPId.Builder
-
optional int64 mostSignificantBits = 1;
- setMostSignificantBits(long) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
optional int64 mostSignificantBits = 1;
- setMountId(long) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setMountId(long) - Method in class alluxio.grpc.Block.Builder
-
optional int64 mountId = 5;
- setMountId(long) - Method in class alluxio.grpc.File.Builder
-
optional int64 mountId = 4;
- setMountId(long) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 mountId = 23;
- setMountId(long) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
required int64 mountId = 1;
- setMountId(long) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
the id of the ufs
- setMountId(long) - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 mountId = 8;
- setMountId(long) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional int64 mount_id = 5;
- setMountId(long) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional int64 mountId = 5;
- setMountId(long) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
optional int64 mount_id = 1;
- setMountId(long) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional int64 mount_id = 6;
- setMountId(long) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
optional int64 mount_id = 2;
- setMountId(long) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
optional int64 mount_id = 2;
- setMountId(long) - Method in class alluxio.wire.FileInfo
-
- setMountId(long) - Method in class alluxio.wire.MountPointInfo
-
- setMountOptions(MountPOptions) - Method in class alluxio.wire.UfsInfo
-
- setMountPoint(boolean) - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool mountPoint = 20;
- setMountPoint(boolean) - Method in class alluxio.master.file.contexts.CreatePathContext
-
- setMountPoint(boolean) - Method in class alluxio.master.file.meta.MutableInodeDirectory
-
- setMountPoint(boolean) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool mount_point = 11;
- setMountPoint(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
optional bool mount_point = 2;
- setMountPoint(String) - Method in class alluxio.util.UnixMountInfo.Builder
-
- setMountPoint(boolean) - Method in class alluxio.wire.FileInfo
-
- setMountPointInfos(Map<String, MountPointInfo>) - Method in class alluxio.wire.MasterWebUIMountTable
-
Sets mount point infos.
- setMountPoints(Map<String, MountPointInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setMoveJob(Job.MoveJobEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- setMoveJob(Job.MoveJobEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
- setMsg(String) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
optional string msg = 1;
- setMsgBytes(ByteString) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
optional string msg = 1;
- setMultipartUploadEnabled(boolean) - Method in class alluxio.underfs.options.CreateOptions
-
- setMyRunningWorker(WorkerInfo) - Method in class alluxio.scheduler.job.Task
-
Set the worker info this task runs on.
- setName(String) - Method in class alluxio.cli.ValidationTaskResult
-
Sets task name.
- setName(String) - Method in class alluxio.conf.PropertyKey.Builder
-
- setName(String) - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string name = 1;
- setName(String) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string name = 2;
- setName(String) - Method in class alluxio.grpc.InconsistentProperty.Builder
-
optional string name = 1;
- setName(String) - Method in class alluxio.grpc.JobInfo.Builder
-
Some jobs don't have these
- setName(String) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional string name = 2;
- setName(String) - Method in class alluxio.grpc.Metric.Builder
-
optional string name = 3;
- setName(String) - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional string name = 2;
- setName(String) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string name = 2;
- setName(String) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string name = 1;
- setName(String) - Method in class alluxio.master.file.meta.MutableInode
-
- setName(String) - Method in class alluxio.metrics.MetricKey.Builder
-
- setName(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string name = 3;
- setName(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string name = 3;
- setName(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string name = 3;
- setName(String) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string name = 1;
- setName(String) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional string name = 2;
- setName(String) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
optional string name = 1;
- setName(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string name = 6;
- setName(String) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional string name = 1;
- setName(String) - Method in class alluxio.s3.ListAllMyBucketsResult.Bucket
-
- setName(String) - Method in class alluxio.underfs.UfsStatus
-
Set the name of file or directory.
- setName(String) - Method in class alluxio.wire.FileInfo
-
- setName(String) - Method in class alluxio.wire.InconsistentProperty
-
- setNameBytes(ByteString) - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string name = 1;
- setNameBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string name = 2;
- setNameBytes(ByteString) - Method in class alluxio.grpc.InconsistentProperty.Builder
-
optional string name = 1;
- setNameBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
-
Some jobs don't have these
- setNameBytes(ByteString) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional string name = 2;
- setNameBytes(ByteString) - Method in class alluxio.grpc.Metric.Builder
-
optional string name = 3;
- setNameBytes(ByteString) - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional string name = 2;
- setNameBytes(ByteString) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string name = 2;
- setNameBytes(ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string name = 1;
- setNameBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string name = 3;
- setNameBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string name = 3;
- setNameBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string name = 3;
- setNameBytes(ByteString) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional string name = 2;
- setNameBytes(ByteString) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
optional string name = 1;
- setNameBytes(ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string name = 6;
- setNameBytes(ByteString) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
optional string name = 1;
- setNettyDataPort(int) - Method in class alluxio.wire.WorkerNetAddress
-
- setNetworkGroup(GrpcNetworkGroup) - Method in class alluxio.grpc.GrpcChannelBuilder
-
Sets the pooling strategy.
- setNewBlock(File.NewBlockEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- setNewBlock(File.NewBlockEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
- setNewerVersionAvailable(boolean) - Method in class alluxio.master.meta.DefaultMetaMaster
-
- setNewerVersionAvailable(boolean) - Method in interface alluxio.master.meta.MetaMaster
-
Sets whether newer version Alluxio is available.
- setNewerVersionAvailable(boolean) - Method in class alluxio.wire.MasterWebUIInit
-
Sets newer version available.
- setNewName(String) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_name = 5;
- setNewNameBytes(ByteString) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_name = 5;
- setNewParentId(long) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 new_parent_id = 4;
- setNewPath(String) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_path = 7;
- setNewPathBytes(ByteString) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string new_path = 7;
- setNextContainerId(long) - Method in class alluxio.master.block.BlockContainerIdGenerator
-
- setNextContainerId(long) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
optional int64 next_container_id = 1;
- setNextSequenceNumber(long) - Method in class alluxio.master.journal.options.JournalReaderOptions
-
- setNextSequenceNumber(long) - Method in class alluxio.master.journal.options.JournalWriterOptions
-
- setNoCache(boolean) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
If set, do not try to cache the block locally when reading the data from the UFS.
- setNodeResults(Map<String, T>) - Method in class alluxio.stress.common.GeneralBenchSummary
-
- setNodeState(NodeState) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
optional .alluxio.grpc.journal.NodeState node_state = 1;
- setNoFormat(boolean) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
-
- setNormalNodeInfos(NodeInfo[]) - Method in class alluxio.wire.MasterWebUIWorkers
-
Sets normal node infos.
- setNTotalFile(int) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets n total file.
- setNTotalFile(int) - Method in class alluxio.wire.MasterWebUILogs
-
Sets n total file.
- setNTotalFile(int) - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Sets n total file.
- setNTotalFile(int) - Method in class alluxio.wire.WorkerWebUILogs
-
Sets n total file.
- setNumActiveTasks(int) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 numActiveTasks = 6;
- setNumDistincts(long) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- setNumDistincts(long) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- setNumDistincts(long) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- setNumDistincts(long) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- setNumDistincts(long) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 num_distincts = 4;
- setNumFalses(long) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_falses = 2;
- setNumMasters(int) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
-
- setNumNulls(long) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- setNumNulls(long) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- setNumNulls(long) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- setNumNulls(long) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- setNumNulls(long) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- setNumNulls(long) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- setNumNulls(long) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional int64 num_nulls = 3;
- setNumOfCandidate(int) - Method in class alluxio.client.file.cache.evictor.NondeterministicLRUCacheEvictor
-
- setNumTrues(long) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional int64 num_trues = 1;
- setNumWorkers(int) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
-
- setObject(String) - Method in class alluxio.s3.S3AuditContext
-
Sets mObject field.
- setOffset(long) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
optional int64 offset = 2;
- setOffset(long) - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 offset = 2;
- setOffset(long) - Method in class alluxio.grpc.SnapshotData.Builder
-
Deprecated.
- setOffset(long) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional int64 offset = 3;
- setOffset(long) - Method in class alluxio.grpc.WriteResponse.Builder
-
optional int64 offset = 1;
- setOffset(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
optional int64 offset = 2;
- setOffset(long) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional int64 offset = 3;
- setOffset(long) - Method in class alluxio.underfs.options.FileLocationOptions
-
Sets the offset for which locations are to be queried.
- setOffset(long) - Method in class alluxio.underfs.options.OpenOptions
-
Sets the offset from the start of a file to be opened for reading.
- setOffset(long) - Method in class alluxio.wire.FileBlockInfo
-
- setOffsetCount(int) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Only start listing items after this many items have been processed.
- setOffsetId(long) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Start listing after the given FileId, the FileId can be calculated from the
result of a previous listing's FileInfo or URIStatus results using the
getFileId method.
- setOffsetInFile(long) - Method in class alluxio.grpc.Block.Builder
-
The offset of the block in within ufs the file.
- setOffsetInFile(long) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The offset of the block in within the file.
- setOffsetReceived(long) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- setOffsetReceived(long) - Method in class alluxio.grpc.ReadRequest.Builder
-
Read receipt
- setOffsetReceived(long) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- setOnlyReserveSpace(boolean) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
If set, only reserve space for the block.
- setOnReadyHandler(Runnable) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
-
- setOpenOrCreateFlags(int) - Method in class alluxio.fuse.file.FuseFileEntry
-
- setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.grpc.CacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.grpc.CacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.grpc.ReadRequest.Builder
-
This is only set for UFS block read.
- setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.grpc.ReadRequest.Builder
-
This is only set for UFS block read.
- setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
This is only set for UFS block read.
- setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
This is only set for UFS block read.
- setOperation(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string operation = 1;
- setOperationBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string operation = 1;
- setOperationCount(long) - Method in class alluxio.wire.WorkerWebUIOperations
-
Sets the operation count.
- setOperationId(FsOpPId) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- setOperationId(FsOpPId.Builder) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.file.FsOpPId operationId = 4;
- setOperationId(Journal.JournalOpPId) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- setOperationId(Journal.JournalOpPId.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
- setOperationMetrics(Map<String, Metric>) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets operation metrics.
- setOperationMetrics(Map<String, Metric>) - Method in class alluxio.wire.WorkerWebUIMetrics
-
Sets operation metrics.
- setOperationTimeMs(long) - Method in class alluxio.master.file.contexts.CompleteFileContext
-
Sets operation time.
- setOperationTimeMs(long) - Method in class alluxio.master.file.contexts.CreatePathContext
-
- setOperationTimeMs(long) - Method in class alluxio.master.file.contexts.RenameContext
-
Sets operation time.
- setOperationTimeMs(long) - Method in class alluxio.master.file.contexts.SetAttributeContext
-
Sets operation time.
- setOperationType(OperationType) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
optional .alluxio.grpc.job.OperationType operationType = 3;
- setOperationType(OperationType) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.OperationType operationType = 2;
- setOpTimeMs(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional int64 op_time_ms = 4;
- setOpTimeMs(long) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional int64 op_time_ms = 3;
- setOpTimeMs(long) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
optional int64 op_time_ms = 3;
- setOpTimeMs(long) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional int64 op_time_ms = 3;
- setOpTimeMs(long) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional int64 op_time_ms = 2;
- setOpTimeMs(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 op_time_ms = 2;
- setOptions(AddPolicyPOptions) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- setOptions(AddPolicyPOptions.Builder) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
- setOptions(BackupPOptions) - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- setOptions(BackupPOptions.Builder) - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional .alluxio.grpc.meta.BackupPOptions options = 1;
- setOptions(BlockHeartbeatPOptions) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- setOptions(BlockHeartbeatPOptions.Builder) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
- setOptions(CancelPOptions) - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- setOptions(CancelPOptions.Builder) - Method in class alluxio.grpc.CancelPRequest.Builder
-
optional .alluxio.grpc.job.CancelPOptions options = 2;
- setOptions(CheckAccessPOptions) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- setOptions(CheckAccessPOptions.Builder) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- setOptions(CheckConsistencyPOptions) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- setOptions(CheckConsistencyPOptions.Builder) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- setOptions(CommitBlockPOptions) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- setOptions(CommitBlockPOptions.Builder) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
- setOptions(CompleteFilePOptions) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- setOptions(CompleteFilePOptions.Builder) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
- setOptions(CreateDirectoryPOptions) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- setOptions(CreateDirectoryPOptions.Builder) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
- setOptions(CreateFilePOptions) - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- setOptions(CreateFilePOptions.Builder) - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
- setOptions(DeletePOptions) - Method in class alluxio.grpc.DeletePRequest.Builder
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- setOptions(DeletePOptions.Builder) - Method in class alluxio.grpc.DeletePRequest.Builder
-
optional .alluxio.grpc.file.DeletePOptions options = 2;
- setOptions(ExistsPOptions) - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- setOptions(ExistsPOptions.Builder) - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional .alluxio.grpc.file.ExistsPOptions options = 2;
- setOptions(FileSystemHeartbeatPOptions) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- setOptions(FileSystemHeartbeatPOptions.Builder) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
- setOptions(FreePOptions) - Method in class alluxio.grpc.FreePRequest.Builder
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- setOptions(FreePOptions.Builder) - Method in class alluxio.grpc.FreePRequest.Builder
-
optional .alluxio.grpc.file.FreePOptions options = 2;
- setOptions(GetPolicyStatusPOptions) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- setOptions(GetPolicyStatusPOptions.Builder) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
- setOptions(GetAllMasterStatusPOptions) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- setOptions(GetAllMasterStatusPOptions.Builder) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
- setOptions(GetAllWorkerHealthPOptions) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- setOptions(GetAllWorkerHealthPOptions.Builder) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
- setOptions(GetBlockInfoPOptions) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- setOptions(GetBlockInfoPOptions.Builder) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
- setOptions(GetCmdStatusOptions) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- setOptions(GetCmdStatusOptions.Builder) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- setOptions(GetCmdStatusOptions) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- setOptions(GetCmdStatusOptions.Builder) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
- setOptions(GetFileInfoPOptions) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- setOptions(GetFileInfoPOptions.Builder) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
- setOptions(GetJobMasterIdPOptions) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- setOptions(GetJobMasterIdPOptions.Builder) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
- setOptions(JobProgressPOptions) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- setOptions(JobProgressPOptions.Builder) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
- setOptions(GetJobServiceSummaryPOptions) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- setOptions(GetJobServiceSummaryPOptions.Builder) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
- setOptions(GetJobStatusDetailedPOptions) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- setOptions(GetJobStatusDetailedPOptions.Builder) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- setOptions(GetJobStatusPOptions) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- setOptions(GetJobStatusPOptions.Builder) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- setOptions(GetMasterIdPOptions) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- setOptions(GetMasterIdPOptions.Builder) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- setOptions(GetNewBlockIdForFilePOptions) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- setOptions(GetNewBlockIdForFilePOptions.Builder) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- setOptions(GetPinnedFileIdsPOptions) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- setOptions(GetPinnedFileIdsPOptions.Builder) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- setOptions(GetPolicyStatusPOptions) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- setOptions(GetPolicyStatusPOptions.Builder) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
- setOptions(GetQuorumInfoPOptions) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- setOptions(GetQuorumInfoPOptions.Builder) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- setOptions(GetRegisterLeasePOptions) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- setOptions(GetRegisterLeasePOptions.Builder) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
- setOptions(GetStateLockHoldersPOptions) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- setOptions(GetStateLockHoldersPOptions.Builder) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- setOptions(GetStatusPOptions) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- setOptions(GetStatusPOptions.Builder) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- setOptions(GetUfsInfoPOptions) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- setOptions(GetUfsInfoPOptions.Builder) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- setOptions(GetWorkerIdPOptions) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- setOptions(GetWorkerIdPOptions.Builder) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- setOptions(JobHeartbeatPOptions) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- setOptions(JobHeartbeatPOptions.Builder) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- setOptions(JobMasterHeartbeatPOptions) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- setOptions(JobMasterHeartbeatPOptions.Builder) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
- setOptions(ListAllPOptions) - Method in class alluxio.grpc.ListAllPRequest.Builder
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- setOptions(ListAllPOptions.Builder) - Method in class alluxio.grpc.ListAllPRequest.Builder
-
optional .alluxio.grpc.job.ListAllPOptions options = 1;
- setOptions(ListPolicyPOptions) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- setOptions(ListPolicyPOptions.Builder) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
- setOptions(ListProxyStatusPOptions) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- setOptions(ListProxyStatusPOptions.Builder) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
- setOptions(ListStatusPOptions) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- setOptions(ListStatusPOptions.Builder) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
- setOptions(ListStatusPartialPOptions) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- setOptions(ListStatusPartialPOptions.Builder) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
- setOptions(ListStatusPOptions) - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- setOptions(ListStatusPOptions.Builder) - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
- setOptions(UfsReadOptions) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- setOptions(UfsReadOptions.Builder) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- setOptions(UfsReadOptions) - Method in class alluxio.grpc.LoadRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- setOptions(UfsReadOptions.Builder) - Method in class alluxio.grpc.LoadRequest.Builder
-
required .alluxio.grpc.block.UfsReadOptions options = 2;
- setOptions(MasterHeartbeatPOptions) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- setOptions(MasterHeartbeatPOptions.Builder) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
- setOptions(MetricsHeartbeatPOptions) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- setOptions(MetricsHeartbeatPOptions.Builder) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
- setOptions(MountPOptions) - Method in class alluxio.grpc.MountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- setOptions(MountPOptions.Builder) - Method in class alluxio.grpc.MountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- setOptions(NotifyWorkerIdPOptions) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- setOptions(NotifyWorkerIdPOptions.Builder) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
- setOptions(AddPolicyPOptions) - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- setOptions(AddPolicyPOptions.Builder) - Method in class alluxio.grpc.PolicyInfo.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- setOptions(ProxyHeartbeatPOptions) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- setOptions(ProxyHeartbeatPOptions.Builder) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
- setOptions(RegisterJobMasterPOptions) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- setOptions(RegisterJobMasterPOptions.Builder) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
- setOptions(RegisterJobWorkerPOptions) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- setOptions(RegisterJobWorkerPOptions.Builder) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
- setOptions(RegisterMasterPOptions) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- setOptions(RegisterMasterPOptions.Builder) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
- setOptions(RegisterWorkerPOptions) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- setOptions(RegisterWorkerPOptions.Builder) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
- setOptions(RemovePathConfigurationPOptions) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- setOptions(RemovePathConfigurationPOptions.Builder) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
- setOptions(RemovePolicyPOptions) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- setOptions(RemovePolicyPOptions.Builder) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
- setOptions(RemoveQuorumServerPOptions) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- setOptions(RemoveQuorumServerPOptions.Builder) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
- setOptions(RenamePOptions) - Method in class alluxio.grpc.RenamePRequest.Builder
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- setOptions(RenamePOptions.Builder) - Method in class alluxio.grpc.RenamePRequest.Builder
-
optional .alluxio.grpc.file.RenamePOptions options = 3;
- setOptions(ResetPrioritiesPOptions) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- setOptions(ResetPrioritiesPOptions.Builder) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- setOptions(RunPOptions) - Method in class alluxio.grpc.RunPRequest.Builder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- setOptions(RunPOptions.Builder) - Method in class alluxio.grpc.RunPRequest.Builder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- setOptions(ScheduleAsyncPersistencePOptions) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- setOptions(ScheduleAsyncPersistencePOptions.Builder) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- setOptions(SetAclPOptions) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the method options
- setOptions(SetAclPOptions.Builder) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the method options
- setOptions(SetAttributePOptions) - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- setOptions(SetAttributePOptions.Builder) - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- setOptions(SetPathConfigurationPOptions) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- setOptions(SetPathConfigurationPOptions.Builder) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- setOptions(SubmitOptions) - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- setOptions(SubmitOptions.Builder) - Method in class alluxio.grpc.SubmitRequest.Builder
-
optional .alluxio.grpc.job.SubmitOptions options = 2;
- setOptions(TransferLeadershipPOptions) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- setOptions(TransferLeadershipPOptions.Builder) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- setOptions(UnmountPOptions) - Method in class alluxio.grpc.UnmountPRequest.Builder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- setOptions(UnmountPOptions.Builder) - Method in class alluxio.grpc.UnmountPRequest.Builder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- setOptions(MountPOptions) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- setOptions(MountPOptions.Builder) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- setOptions(UpdateUfsModePOptions) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- setOptions(UpdateUfsModePOptions.Builder) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- setOptions(AddPolicyPOptions) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- setOptions(AddPolicyPOptions.Builder) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
- setOptions(UnixMountInfo.Options) - Method in class alluxio.util.UnixMountInfo.Builder
-
- setOrder(SortingColumn.SortingOrder) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
- setOrderedTierAliases(List<String>) - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Sets ordered tier aliases.
- setOssClientBuilder(OSSClientBuilder) - Method in class alluxio.underfs.oss.StsOssClientProvider
-
- setOtherActions(Acl.AclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- setOtherActions(Acl.AclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional .alluxio.proto.shared.AclActions otherActions = 6;
- setOtherBits(Bits) - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits otherBits = 3;
- setOtherBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
-
Sets other bits.
- setOutput(String) - Method in class alluxio.cli.ValidationTaskResult
-
Sets task output.
- setOutputFormat(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string output_format = 3;
- setOutputFormatBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string output_format = 3;
- setOutputStream(OutputStream) - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
-
- setOutputStream(OutputStream) - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
-
- setOverheadRatio(double) - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- setOverwrite(boolean) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool overwrite = 4;
- setOverwrite(boolean) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool overwrite = 13;
- setOverwrite(boolean) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool overwrite = 4;
- setOverwrite(boolean) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
optional bool overwrite = 1;
- setOverwrite(boolean) - Method in class alluxio.grpc.WriteOptions.Builder
-
optional bool overwrite = 1;
- setOverwrite(boolean) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional bool overwrite = 10;
- setOverwrite(boolean) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional bool overwrite = 10;
- setOverwriteAccessTime(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool overwrite_access_time = 19;
- setOverwriteModificationTime(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool overwrite_modification_time = 8;
- setOwner(String) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setOwner(String, String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- setOwner(String) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string owner = 16;
- setOwner(String) - Method in class alluxio.grpc.PAcl.Builder
-
optional string owner = 1;
- setOwner(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string owner = 3;
- setOwner(String) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string owner = 4;
- setOwner(String) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string owner = 4;
- setOwner(Path, String, String) - Method in class alluxio.hadoop.AbstractFileSystem
-
Changes owner or group of a path (i.e.
- setOwner(String) - Method in class alluxio.master.file.contexts.CreatePathContext
-
- setOwner(String) - Method in class alluxio.master.file.meta.MutableInode
-
- setOwner(String) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string owner = 2;
- setOwner(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string owner = 8;
- setOwner(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string owner = 14;
- setOwner(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string owner = 6;
- setOwner(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string owner = 9;
- setOwner(String, String, String) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
-
- setOwner(String, String, String) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
-
- setOwner(String, String, String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- setOwner(String, String, String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- setOwner(String, String, String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- setOwner(String, String, String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- setOwner(String, String, String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- setOwner(String, String, String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- setOwner(String, String, String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
-
- setOwner(String) - Method in class alluxio.underfs.options.CreateOptions
-
- setOwner(String) - Method in class alluxio.underfs.options.MkdirsOptions
-
- setOwner(String, String, String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- setOwner(String, String, String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- setOwner(String, String, String) - Method in interface alluxio.underfs.UnderFileSystem
-
Sets the user and group of the given path.
- setOwner(String, String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- setOwner(String) - Method in class alluxio.wire.FileInfo
-
- setOwnerBits(Bits) - Method in class alluxio.grpc.PMode.Builder
-
required .alluxio.grpc.Bits ownerBits = 1;
- setOwnerBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
-
Sets owner bits.
- setOwnerBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string owner = 16;
- setOwnerBytes(ByteString) - Method in class alluxio.grpc.PAcl.Builder
-
optional string owner = 1;
- setOwnerBytes(ByteString) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional string owner = 3;
- setOwnerBytes(ByteString) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string owner = 4;
- setOwnerBytes(ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string owner = 4;
- setOwnerBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string owner = 2;
- setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string owner = 8;
- setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string owner = 14;
- setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string owner = 6;
- setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string owner = 9;
- setOwnerName(String) - Method in class alluxio.grpc.table.Database.Builder
-
optional string owner_name = 5;
- setOwnerNameBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
-
optional string owner_name = 5;
- setOwnerType(PrincipalType) - Method in class alluxio.grpc.table.Database.Builder
-
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
- setOwningGroup(String) - Method in class alluxio.grpc.PAcl.Builder
-
optional string owningGroup = 2;
- setOwningGroup(String) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningGroup = 2;
- setOwningGroup(String) - Method in class alluxio.security.authorization.AccessControlList
-
Sets owning group.
- setOwningGroupBytes(ByteString) - Method in class alluxio.grpc.PAcl.Builder
-
optional string owningGroup = 2;
- setOwningGroupBytes(ByteString) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningGroup = 2;
- setOwningUser(String) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningUser = 1;
- setOwningUser(String) - Method in class alluxio.security.authorization.AccessControlList
-
Sets owning user.
- setOwningUserBytes(ByteString) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
optional string owningUser = 1;
- setPacketReaderActive(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
-
- setPacketWriterActive(boolean) - Method in class alluxio.worker.netty.WriteRequestContext
-
- setPageSize(long) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setPageSize(long) - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- setPageSize(long) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
optional int64 pageSize = 1;
- setPageStoreOptions(List<PageStoreOptions>) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setParameters(ClientIOParameters) - Method in class alluxio.stress.client.ClientIOSummary
-
- setParameters(ClientIOParameters) - Method in class alluxio.stress.client.ClientIOTaskResult
-
- setParameters(UfsIOParameters) - Method in class alluxio.stress.worker.IOTaskResult
-
- setParameters(UfsIOParameters) - Method in class alluxio.stress.worker.IOTaskSummary
-
- setParameters(WorkerBenchParameters) - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- setParameters(WorkerBenchParameters) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- setParentId(long) - Method in class alluxio.grpc.JobInfo.Builder
-
optional int64 parentId = 10;
- setParentId(long) - Method in class alluxio.master.file.meta.MutableInode
-
- setParentId(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 parent_id = 2;
- setParentId(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 parent_id = 2;
- setParentId(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 parent_id = 2;
- setParentId(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 parent_id = 7;
- setPartialListing(boolean) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool partialListing = 3;
- setPartialListing(boolean) - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool partialListing = 3;
- setPartialListing(boolean) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool partialListing = 3;
- setPartialListing(boolean) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required bool partialListing = 7;
- setPartialListing(boolean) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required bool partialListing = 6;
- setPartialListing(boolean) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required bool partialListing = 7;
- setPartitionCols(int, FieldSchema) - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- setPartitionCols(int, FieldSchema.Builder) - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- setPartitionName(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
partition name in the form of "key=value"
- setPartitionNameBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
partition name in the form of "key=value"
- setPartitions(int, Partition) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- setPartitions(int, Partition.Builder) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 1;
- setPartitionSpec(PartitionSpec) - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- setPartitionSpec(PartitionSpec.Builder) - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- setPartNames(int, String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string part_names = 4;
- setPartNumber(int) - Method in class alluxio.proxy.s3.ListPartsResult.Part
-
- setParts(List<CompleteMultipartUploadRequest.Part>) - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest
-
- setParts(List<ListPartsResult.Part>) - Method in class alluxio.proxy.s3.ListPartsResult
-
- setPath(String) - Method in class alluxio.fuse.CreateFileEntry
-
Sets the path of the file.
- setPath(String) - Method in class alluxio.fuse.OpenFileEntry
-
Sets the path of the file.
- setPath(String) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional string path = 1;
- setPath(String) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
the root of the subtree to check
- setPath(String) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
the path of the file
- setPath(String) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
the path of the directory
- setPath(String) - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
the path of the file
- setPath(String) - Method in class alluxio.grpc.DeletePRequest.Builder
-
the path of the file or directory
- setPath(String) - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional string path = 1;
- setPath(String) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string path = 3;
- setPath(String) - Method in class alluxio.grpc.FreePRequest.Builder
-
the path of the file or directory
- setPath(String) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
optional string path = 1;
- setPath(String) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
the path of the file
- setPath(String) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
the path of the file or directory
- setPath(String) - Method in class alluxio.grpc.JobDescription.Builder
-
optional string path = 2;
- setPath(String) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
the path of the file or directory
- setPath(String) - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
the path of the file or directory
- setPath(String) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
required string path = 1;
- setPath(String) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional string path = 1;
- setPath(String) - Method in class alluxio.grpc.RenamePRequest.Builder
-
the source path of the file or directory
- setPath(String) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
the path of the file
- setPath(String) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the path of the file or directory
- setPath(String) - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
the path of the file
- setPath(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional string path = 1;
- setPath(String) - Method in class alluxio.job.JobDescription.Builder
-
set path.
- setPath(String) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
optional string path = 1;
- setPath(String) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
optional string path = 1;
- setPath(String) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional string path = 5;
- setPath(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string path = 17;
- setPath(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string path = 25;
- setPath(String) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string path = 6;
- setPath(String) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string path = 12;
- setPath(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
optional string path = 1;
- setPath(String) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
optional string path = 1;
- setPath(String) - Method in class alluxio.wire.FileInfo
-
- setPath(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
-
Sets path.
- setPathBytes(ByteString) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional string path = 1;
- setPathBytes(ByteString) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
the root of the subtree to check
- setPathBytes(ByteString) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
the path of the file
- setPathBytes(ByteString) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
the path of the directory
- setPathBytes(ByteString) - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
the path of the file
- setPathBytes(ByteString) - Method in class alluxio.grpc.DeletePRequest.Builder
-
the path of the file or directory
- setPathBytes(ByteString) - Method in class alluxio.grpc.ExistsPRequest.Builder
-
optional string path = 1;
- setPathBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string path = 3;
- setPathBytes(ByteString) - Method in class alluxio.grpc.FreePRequest.Builder
-
the path of the file or directory
- setPathBytes(ByteString) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
optional string path = 1;
- setPathBytes(ByteString) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
the path of the file
- setPathBytes(ByteString) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
the path of the file or directory
- setPathBytes(ByteString) - Method in class alluxio.grpc.JobDescription.Builder
-
optional string path = 2;
- setPathBytes(ByteString) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
the path of the file or directory
- setPathBytes(ByteString) - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
the path of the file or directory
- setPathBytes(ByteString) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
required string path = 1;
- setPathBytes(ByteString) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
optional string path = 1;
- setPathBytes(ByteString) - Method in class alluxio.grpc.RenamePRequest.Builder
-
the source path of the file or directory
- setPathBytes(ByteString) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
the path of the file
- setPathBytes(ByteString) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the path of the file or directory
- setPathBytes(ByteString) - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
the path of the file
- setPathBytes(ByteString) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional string path = 1;
- setPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
optional string path = 1;
- setPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
optional string path = 1;
- setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
optional string path = 5;
- setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string path = 17;
- setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string path = 25;
- setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
optional string path = 6;
- setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string path = 12;
- setPathBytes(ByteString) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
optional string path = 1;
- setPathBytes(ByteString) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
optional string path = 1;
- setPathConfHash(String) - Method in class alluxio.wire.Configuration.Builder
-
Sets hash of path configurations.
- setPathConfigHash(String) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string pathConfigHash = 2;
- setPathConfigHash(String) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string pathConfigHash = 4;
- setPathConfigHash(String) - Method in class alluxio.wire.WorkerWebUIConfiguration
-
Sets path config hash.
- setPathConfigHashBytes(ByteString) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
optional string pathConfigHash = 2;
- setPathConfigHashBytes(ByteString) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional string pathConfigHash = 4;
- setPathConfigLastUpdateTime(long) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
optional int64 pathConfigLastUpdateTime = 6;
- setPathConfigLastUpdateTime(String) - Method in class alluxio.wire.WorkerWebUIConfiguration
-
Sets the path config last update time.
- setPathConfiguration(AlluxioURI, PropertyKey, String) - Method in interface alluxio.client.meta.MetaMasterConfigClient
-
Sets a property for a path.
- setPathConfiguration(AlluxioURI, Map<PropertyKey, String>) - Method in interface alluxio.client.meta.MetaMasterConfigClient
-
Sets properties for a path.
- setPathConfiguration(AlluxioURI, Map<PropertyKey, String>) - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
-
- setPathConfiguration(SetPathConfigurationPRequest, StreamObserver<SetPathConfigurationPResponse>) - Method in interface alluxio.grpc.MetaMasterConfigurationServiceGrpc.AsyncService
-
Sets a property for a path.
- setPathConfiguration(SetPathConfigurationPRequest) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceBlockingStub
-
Sets a property for a path.
- setPathConfiguration(SetPathConfigurationPRequest) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub
-
Sets a property for a path.
- setPathConfiguration(SetPathConfigurationPRequest, StreamObserver<SetPathConfigurationPResponse>) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub
-
Sets a property for a path.
- setPathConfiguration(String, Map<PropertyKey, String>) - Method in class alluxio.master.meta.DefaultMetaMaster
-
- setPathConfiguration(String, Map<PropertyKey, String>) - Method in interface alluxio.master.meta.MetaMaster
-
Sets properties for a path.
- setPathConfiguration(SetPathConfigurationPRequest, StreamObserver<SetPathConfigurationPResponse>) - Method in class alluxio.master.meta.MetaMasterConfigurationServiceHandler
-
- SetPathConfigurationPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.SetPathConfigurationPOptions
- SetPathConfigurationPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.SetPathConfigurationPOptions
- SetPathConfigurationPOptionsOrBuilder - Interface in alluxio.grpc
-
- SetPathConfigurationPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.SetPathConfigurationPRequest
- SetPathConfigurationPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.SetPathConfigurationPRequest
- SetPathConfigurationPRequestOrBuilder - Interface in alluxio.grpc
-
- SetPathConfigurationPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.SetPathConfigurationPResponse
- SetPathConfigurationPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.SetPathConfigurationPResponse
- SetPathConfigurationPResponseOrBuilder - Interface in alluxio.grpc
-
- setPathConfLastUpdateTime(long) - Method in class alluxio.wire.Configuration.Builder
-
Sets path config last update time.
- setPathInfos(UIFileInfo[]) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets path infos.
- setPathProperties(Meta.PathPropertiesEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- setPathProperties(Meta.PathPropertiesEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
- setPattern(String) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
optional string pattern = 2;
- setPatternBytes(ByteString) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
optional string pattern = 2;
- setPendingCount(int) - Method in class alluxio.concurrent.jsr.CountedCompleter
-
Sets the pending count to the given value.
- setPermission(Path, FsPermission) - Method in class alluxio.hadoop.AbstractFileSystem
-
Changes permission of a path.
- setPermission(int) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 permission = 8;
- setPermissionError(String) - Method in class alluxio.wire.MasterWebUIData
-
Sets permission error.
- setPersist(boolean) - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional bool persist = 2;
- setPersistDirectory(File.PersistDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- setPersistDirectory(File.PersistDirectoryEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
- setPersisted(boolean) - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool persisted = 12;
- setPersisted(boolean) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool persisted = 2;
- setPersisted(boolean) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional bool persisted = 5;
- setPersisted(boolean) - Method in class alluxio.wire.FileInfo
-
- setPersistedFileFingerprints(int, String) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
repeated string persistedFileFingerprints = 1;
- setPersistedFiles(int, long) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
the list of persisted files
- setPersistenceState(String) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string persistenceState = 19;
- setPersistenceState(PersistenceState) - Method in class alluxio.master.file.meta.MutableInode
-
- setPersistenceState(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string persistence_state = 4;
- setPersistenceState(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string persistence_state = 4;
- setPersistenceState(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string persistence_state = 4;
- setPersistenceState(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persistence_state = 8;
- setPersistenceState(String) - Method in class alluxio.wire.FileInfo
-
- setPersistenceStateBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string persistenceState = 19;
- setPersistenceStateBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional string persistence_state = 4;
- setPersistenceStateBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string persistence_state = 4;
- setPersistenceStateBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string persistence_state = 4;
- setPersistenceStateBytes(ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persistence_state = 8;
- setPersistenceWaitTime(long) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setPersistenceWaitTime(long) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int64 persistenceWaitTime = 10;
- setPersistenceWaitTime(long) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional int64 persistenceWaitTime = 2;
- setPersistFiles(int, PersistFile) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- setPersistFiles(int, PersistFile.Builder) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- setPersistJobId(long) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setPersistJobId(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 persist_job_id = 22;
- setPersistJobId(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 persistJobId = 11;
- setPersistJobId(long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int64 persist_job_id = 10;
- setPersistJobId(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
Used for recovering in-progress file persist jobs on master start.
- setPersistJobTempUfsPath(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persist_job_temp_ufs_path = 24;
- setPersistJobTempUfsPathBytes(ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string persist_job_temp_ufs_path = 24;
- setPersistOptions(PersistCommandOptions) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- setPersistOptions(PersistCommandOptions.Builder) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
- setPersistOptions(PersistCommandOptions) - Method in class alluxio.wire.FileSystemCommandOptions
-
Set the persist options.
- setPinned(FileSystem, AlluxioURI, boolean, List<String>) - Static method in class alluxio.cli.fs.command.FileSystemCommandUtils
-
Sets pin state for the input path.
- setPinned(boolean) - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool pinned = 10;
- setPinned(boolean) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool pinned = 1;
- setPinned(RpcContext, LockedInodePath, boolean, List<String>, long) - Method in class alluxio.master.file.meta.InodeTree
-
Sets the pinned state of an inode.
- setPinned(boolean) - Method in class alluxio.master.file.meta.MutableInode
-
- setPinned(boolean) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional bool pinned = 5;
- setPinned(boolean) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool pinned = 5;
- setPinned(boolean) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional bool pinned = 3;
- setPinned(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional bool pinned = 5;
- setPinned(boolean) - Method in class alluxio.wire.FileInfo
-
- setPinnedFileIds(int, long) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
TODO(adit): set replacement?
- setPinnedMedia(int, String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
repeated string pinnedMedia = 10;
- setPinOnCreate(boolean) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional bool pin_on_create = 9;
- setPoints(List<IOTaskResult.Point>) - Method in class alluxio.stress.worker.IOTaskResult
-
- setPoints(List<IOTaskResult.Point>) - Method in class alluxio.stress.worker.IOTaskSummary
-
- setPolicy(PolicyInfo) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- setPolicy(PolicyInfo.Builder) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
- setPolicy(int, PolicyInfo) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- setPolicy(int, PolicyInfo.Builder) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
- setPolicyDefinition(Policy.PolicyDefinitionEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- setPolicyDefinition(Policy.PolicyDefinitionEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
- setPolicyName(String) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional string policyName = 1;
- setPolicyName(String) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string policyName = 1;
- setPolicyName(String) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional string policyName = 1;
- setPolicyName(String) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional string policyName = 1;
- setPolicyName(String) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
optional string policyName = 1;
- setPolicyNameBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
optional string policyName = 1;
- setPolicyNameBytes(ByteString) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
optional string policyName = 1;
- setPolicyNameBytes(ByteString) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
optional string policyName = 1;
- setPolicyNameBytes(ByteString) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
optional string policyName = 1;
- setPolicyNameBytes(ByteString) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
optional string policyName = 1;
- setPolicyRemove(Policy.PolicyRemoveEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- setPolicyRemove(Policy.PolicyRemoveEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
- setPort(int) - Method in class alluxio.master.CoreMasterContext.Builder
-
- setPos(long) - Method in class alluxio.worker.grpc.WriteRequestContext
-
- setPositionShort(boolean) - Method in class alluxio.grpc.ReadRequest.Builder
-
Is position read to a small buffer
- setPositionShort(boolean) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
is position short or not, used for HDFS performance optimization.
- setPositionShort(boolean) - Method in class alluxio.underfs.options.OpenOptions
-
- setPosReceived(long) - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- setPosToQueue(long) - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- setPosToQueue(long) - Method in class alluxio.worker.netty.ReadRequestContext
-
- setPosToQueue(long) - Method in class alluxio.worker.netty.WriteRequestContext
-
- setPosToWrite(long) - Method in class alluxio.worker.netty.ReadRequestContext
-
- setPosToWrite(long) - Method in class alluxio.worker.netty.WriteRequestContext
-
- setPrefix(String) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Only match files with a given prefix.
- setPrefix(String) - Method in class alluxio.master.metastore.ReadOption.Builder
-
Set the prefix of the path to filter children by.
- setPrefix(String) - Method in class alluxio.s3.ListBucketOptions
-
- setPrefixBytes(ByteString) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Only match files with a given prefix.
- setPreviousVersion(long) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 previous_version = 9;
- setPrimary(boolean) - Method in class alluxio.master.journal.options.JournalReaderOptions
-
- setPrimary(boolean) - Method in class alluxio.master.journal.options.JournalWriterOptions
-
- setPrimaryMasterInfo(MasterInfo) - Method in class alluxio.wire.MasterWebUIMasters
-
Sets primary master info.
- setPrimarySelector(PrimarySelector) - Method in class alluxio.master.CoreMasterContext.Builder
-
- setPriority(int) - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional int32 priority = 4;
- setPriority(int) - Method in class alluxio.scheduler.job.Task
-
Set priority.
- setProgressPercentage(float) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional float progressPercentage = 9;
- setProgressReport(String) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
optional string progressReport = 1;
- setProgressReportBytes(ByteString) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
optional string progressReport = 1;
- setPromote(boolean) - Method in class alluxio.grpc.ReadRequest.Builder
-
Whether the block should be promoted before reading
- setPromote(boolean) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
optional bool promote = 2;
- setPromote(boolean) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
Whether the block should be promoted before reading
- setProperties(int, ConfigProperty) - Method in class alluxio.grpc.ConfigProperties.Builder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- setProperties(int, ConfigProperty.Builder) - Method in class alluxio.grpc.ConfigProperties.Builder
-
repeated .alluxio.grpc.ConfigProperty properties = 1;
- setProperties(int, InconsistentProperty) - Method in class alluxio.grpc.InconsistentProperties.Builder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- setProperties(int, InconsistentProperty.Builder) - Method in class alluxio.grpc.InconsistentProperties.Builder
-
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
- setProperties(MountPOptions) - Method in class alluxio.grpc.UfsInfo.Builder
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- setProperties(MountPOptions.Builder) - Method in class alluxio.grpc.UfsInfo.Builder
-
optional .alluxio.grpc.file.MountPOptions properties = 2;
- setProperties(int, File.StringPairEntry) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- setProperties(int, File.StringPairEntry.Builder) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- setProperties(Map<String, String>) - Method in class alluxio.wire.MountPointInfo
-
- setProperty(PropertyKey, String) - Method in class alluxio.master.LocalAlluxioJobCluster
-
Overrides properties for the Job Master and Worker before starting.
- setProxyAddress(NetAddress) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- setProxyAddress(NetAddress.Builder) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.NetAddress proxyAddress = 1;
- setProxyDownloadFileApiUrl(Map<String, String>) - Method in class alluxio.wire.MasterWebUIInit
-
Sets proxy download file api url.
- setProxyStatuses(int, ProxyStatus) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- setProxyStatuses(int, ProxyStatus.Builder) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
- setQuiet(boolean) - Method in class alluxio.s3.DeleteObjectsRequest
-
sets the quiet parameter.
- setQuietTimeMs(long) - Method in class alluxio.master.journal.JournalSystem.Builder
-
- setQuota(String, long) - Method in class alluxio.underfs.UfsIOManager
-
Set throughput quota for tag.
- setQuotaEnabled(boolean) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setRaftAddress(int, String) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated string raftAddress = 13;
- setRaftJournal(boolean) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional bool raftJournal = 12;
- setRaftJournalAddress(List<String>) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set raft journal address.
- setRange(RangeSet) - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.RangeSet range = 1;
- setRange(RangeSet.Builder) - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.RangeSet range = 1;
- setRanges(int, Range) - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- setRanges(int, Range.Builder) - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- setRawResult(T) - Method in class alluxio.concurrent.jsr.CountedCompleter
-
A method that result-bearing CountedCompleters may optionally use to help maintain result data.
- setRawResult(V) - Method in class alluxio.concurrent.jsr.ForkJoinTask
-
Forces the given value to be returned as a result.
- setRawValue(boolean) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool rawValue = 1;
- setReadFrom(String) - Method in class alluxio.master.metastore.ReadOption.Builder
-
Set the path where to start traversing the list of children from.
- setReadOnly(boolean) - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional bool readOnly = 5;
- setReadOnly(boolean) - Method in class alluxio.grpc.MountPOptions.Builder
-
optional bool readOnly = 1;
- setReadOnly(boolean) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional bool readOnly = 3;
- setReadOnly(boolean) - Method in class alluxio.wire.MountPointInfo
-
- setReadSpeedStat(IOTaskSummary.SpeedStat) - Method in class alluxio.stress.worker.IOTaskSummary
-
- setReadType(ReadPType) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.ReadPType readType = 1;
- setRecentActivities(int, JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- setRecentActivities(int, JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- setRecentFailedJobs(List<JobServiceOutput.SerializableJobInfo>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Set recent failed jobs.
- setRecentFailures(int, JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- setRecentFailures(int, JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- setRecentModifiedJobs(List<JobServiceOutput.SerializableJobInfo>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Set recent modified jobs.
- setRecordStartMs(long) - Method in class alluxio.stress.client.ClientIOTaskResult
-
- setRecordStartMs(long) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- setRecordStartMs(long) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- setRecoverFailedOpen(boolean) - Method in class alluxio.underfs.options.OpenOptions
-
- setRecursive(boolean) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool recursive = 1;
- setRecursive(boolean) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool recursive = 2;
- setRecursive(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool recursive = 1;
- setRecursive(boolean) - Method in class alluxio.grpc.FreePOptions.Builder
-
optional bool recursive = 1;
- setRecursive(boolean) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional bool recursive = 4;
- setRecursive(boolean) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
whether to load metadata recursively
- setRecursive(boolean) - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional bool recursive = 2;
- setRecursive(boolean) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool recursive = 6;
- setRecursive(boolean) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
Deprecated, we now write one journal entry per inode removed
- setRecursive(boolean) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional bool recursive = 5;
- setRecursive(boolean) - Method in class alluxio.underfs.options.DeleteOptions
-
Sets recursive delete.
- setRecursive(boolean) - Method in class alluxio.underfs.options.ListOptions
-
Sets recursive list.
- setRefreshInterval(int) - Method in class alluxio.wire.MasterWebUIInit
-
Sets refresh interval.
- setRefreshInterval(int) - Method in class alluxio.wire.WorkerWebUIInit
-
Sets refresh interval.
- setRegisterCommand(RegisterCommand) - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- setRegisterCommand(RegisterCommand.Builder) - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- setRemovedBlockIds(int, long) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the list of removed block ids
- setRemovePathProperties(Meta.RemovePathPropertiesEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- setRemovePathProperties(Meta.RemovePathPropertiesEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- setRemoveSyncPoint(File.RemoveSyncPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- setRemoveSyncPoint(File.RemoveSyncPointEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- setRename(File.RenameEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- setRename(File.RenameEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RenameEntry rename = 19;
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ActionInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BackupPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BackupPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BackupPStatus.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.Block.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockIdList.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockLocation.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockStatus.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BuildVersion.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CacheRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CacheResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CancelPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CancelPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CancelPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.Chunk.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ClientMetrics.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CmdProgress.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CmdSummary.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.Command.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ConfigProperties.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ConfigProperty.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CopyRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CopyResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DeletePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DeletePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DeletePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ErrorInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ExistsPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ExistsPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ExistsPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.File.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileFailure.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemCommand.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FreePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FreePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FreePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FsOpPId.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
Deprecated.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.InconsistentProperties.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobCommand.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobDescription.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobProgress.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobUnused.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListAllPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MasterInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MasterVersion.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.Metric.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MetricValue.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MountPointInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MountPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MountPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MountPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MoveBlockResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MoveRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MoveResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NetAddress.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PAcl.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PAclEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PersistFile.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PMode.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PolicyInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PolicyStatus.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ProxyStatus.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ReadRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ReadResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterCommand.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RenamePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RenamePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RenamePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RetryInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.Route.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RouteFailure.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RunPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RunPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RunPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RunTaskCommand.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SaslMessage.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAclPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAclPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAttributePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SnapshotData.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StatusSummary.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StopJobPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StopJobPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StorageList.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SubmitOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SubmitRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SubmitResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Constraint.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Database.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Date.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Decimal.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Domain.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Layout.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Partition.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Range.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.RangeSet.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Schema.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.TableInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Transformation.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Value.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TierList.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransportMessage.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UfsFileStatus.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UfsInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UfsStatus.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UnmountPOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UnmountPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UnmountPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WorkerIdentity.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WorkerInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WriteOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WriteRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WriteResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
- setReplicaBlockCount(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets replica block count.
- setReplication(Path, short) - Method in class alluxio.hadoop.AbstractFileSystem
-
- setReplication(RpcContext, LockedInodePath, Integer, Integer, long) - Method in class alluxio.master.file.meta.InodeTree
-
Sets the min and/or max replication level of an inode.
- setReplicationDurable(int) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setReplicationDurable(int) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationDurable = 6;
- setReplicationDurable(int) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setReplicationDurable(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_durable = 24;
- setReplicationDurable(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_durable = 20;
- setReplicationMax(int) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setReplicationMax(int) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationMax = 4;
- setReplicationMax(int) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 replicationMax = 29;
- setReplicationMax(int) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional int32 replicationMax = 7;
- setReplicationMax(int) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setReplicationMax(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_max = 20;
- setReplicationMax(int) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 replication_max = 13;
- setReplicationMax(int) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int32 replication_max = 8;
- setReplicationMax(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_max = 21;
- setReplicationMax(int) - Method in class alluxio.wire.FileInfo
-
- setReplicationMin(int) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setReplicationMin(int) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 replicationMin = 5;
- setReplicationMin(int) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int32 replicationMin = 30;
- setReplicationMin(int) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional int32 replicationMin = 8;
- setReplicationMin(int) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setReplicationMin(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int32 replication_min = 21;
- setReplicationMin(int) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int32 replication_min = 14;
- setReplicationMin(int) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional int32 replication_min = 9;
- setReplicationMin(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int32 replication_min = 22;
- setReplicationMin(int) - Method in class alluxio.wire.FileInfo
-
- setReport(ConfigCheckReport) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- setReport(ConfigCheckReport.Builder) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
- setRequestBody(ByteString) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
optional bytes request_body = 1;
- setRequestHeader(MessagingRequestHeader) - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- setRequestHeader(MessagingRequestHeader.Builder) - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
- setRequestId(long) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
optional int64 requestId = 1;
- setRequestId(long) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
optional int64 requestId = 1;
- setRequestId(String) - Method in class alluxio.s3.S3Error
-
- setResource(String) - Method in class alluxio.s3.S3Error
-
- setResource(String) - Method in exception alluxio.s3.S3Exception
-
- setResponse(HttpResponse) - Method in class alluxio.worker.s3.S3NettyHandler
-
set FullHttpResponse for this request.
- setResponseHeader(MessagingResponseHeader) - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- setResponseHeader(MessagingResponseHeader.Builder) - Method in class alluxio.grpc.TransportMessage.Builder
-
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
- setResult(Map<ValidationUtils.State, List<ValidationTaskResult>>) - Method in class alluxio.cli.ValidationResults
-
Set validation results.
- setResult(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
-
optional bytes result = 9;
- setResult(String) - Method in class alluxio.job.plan.meta.PlanInfo
-
- setResult(Serializable) - Method in class alluxio.job.wire.TaskInfo
-
- setRetryable(boolean) - Method in class alluxio.grpc.BlockStatus.Builder
-
optional bool retryable = 4;
- setRetryable(boolean) - Method in class alluxio.grpc.FileFailure.Builder
-
optional bool retryable = 4;
- setRetryable(boolean) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional bool retryable = 4;
- setRetryable(boolean) - Method in class alluxio.grpc.RouteFailure.Builder
-
optional bool retryable = 4;
- setRevision(String) - Method in class alluxio.grpc.BuildVersion.Builder
-
the git revision at the time of building
- setRevision(String) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string revision = 5;
- setRevision(String) - Method in class alluxio.master.meta.MasterInfo
-
- setRevision(String) - Method in class alluxio.master.meta.ProxyInfo
-
- setRevision(String) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setRevision(String) - Method in class alluxio.wire.AlluxioWorkerInfo
-
- setRevision(String) - Method in class alluxio.wire.MasterInfo
-
- setRevision(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets revision.
- setRevision(String) - Method in class alluxio.wire.WorkerInfo
-
- setRevision(String) - Method in class alluxio.wire.WorkerWebUIOverview
-
Sets revision.
- setRevisionBytes(ByteString) - Method in class alluxio.grpc.BuildVersion.Builder
-
the git revision at the time of building
- setRevisionBytes(ByteString) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string revision = 5;
- setRevisionNumber(long) - Method in class alluxio.membership.DefaultServiceEntity
-
Set revision number.
- setRootDir(Path) - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- setRoute(Route) - Method in class alluxio.grpc.RouteFailure.Builder
-
required .alluxio.grpc.block.Route route = 1;
- setRoute(Route.Builder) - Method in class alluxio.grpc.RouteFailure.Builder
-
required .alluxio.grpc.block.Route route = 1;
- setRoutes(int, Route) - Method in class alluxio.grpc.CopyRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- setRoutes(int, Route.Builder) - Method in class alluxio.grpc.CopyRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- setRoutes(int, Route) - Method in class alluxio.grpc.MoveRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- setRoutes(int, Route.Builder) - Method in class alluxio.grpc.MoveRequest.Builder
-
repeated .alluxio.grpc.block.Route routes = 1;
- setRpcAddress(String) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setRpcAddress(String) - Method in class alluxio.wire.AlluxioWorkerInfo
-
- setRpcInvocationMetrics(Map<String, Counter>) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets rpc invocation metrics.
- setRpcPort(int) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set rpc port.
- setRpcPort(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int32 rpcPort = 3;
- setRpcPort(int) - Method in class alluxio.grpc.NetAddress.Builder
-
optional int32 rpcPort = 2;
- setRpcPort(int) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 rpcPort = 2;
- setRpcPort(int) - Method in class alluxio.wire.Address
-
- setRpcPort(int) - Method in class alluxio.wire.WorkerNetAddress
-
- setRpcQueueLength(long) - Method in class alluxio.wire.WorkerWebUIOperations
-
Sets the RPC queue length.
- setRunAsync(boolean) - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool runAsync = 2;
- setRunTaskCommand(RunTaskCommand) - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- setRunTaskCommand(RunTaskCommand.Builder) - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
- setS3SyntaxOptions(S3SyntaxOptions) - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- setS3SyntaxOptions(S3SyntaxOptions.Builder) - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
- setS3Task(S3BaseTask) - Method in class alluxio.proxy.s3.S3Handler
-
set S3Task for this S3Handler.
- setS3Task(S3NettyBaseTask) - Method in class alluxio.worker.s3.S3NettyHandler
-
set S3Task for this S3Handler.
- setSafeMode(boolean) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set if in safe mode.
- setSafeMode(boolean) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional bool safeMode = 4;
- setSafeModeManager(SafeModeManager) - Method in class alluxio.master.CoreMasterContext.Builder
-
- setScale(int) - Method in class alluxio.grpc.table.Decimal.Builder
-
force using scale first in Decimal.compareTo
- setScanCompleted(long) - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanCompleted = 4;
- setScanPendingAction(long) - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanPendingAction = 3;
- setScanStartedMs(long) - Method in class alluxio.grpc.PolicyStatus.Builder
-
scan status
- setScanTotal(long) - Method in class alluxio.grpc.PolicyStatus.Builder
-
optional int64 scanTotal = 2;
- setSchema(Schema) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Schema schema = 5;
- setSchema(Schema.Builder) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.Schema schema = 5;
- setScope(Scope) - Method in class alluxio.conf.PropertyKey.Builder
-
- setSecond(T2) - Method in class alluxio.collections.Pair
-
Set the second value.
- setSecond(LockedInodePath) - Method in class alluxio.master.file.meta.InodePathPair
-
- setSecureRpcPort(int) - Method in class alluxio.wire.WorkerNetAddress
-
- setSecurityAuthorizationPermissionEnabled(boolean) - Method in class alluxio.wire.MasterWebUIInit
-
Sets security authorization permission enabled.
- setSecurityAuthorizationPermissionEnabled(boolean) - Method in class alluxio.wire.WorkerWebUIInit
-
Sets security authorization permission enabled.
- setSelectionPolicy(DynamicResourcePool.SelectionPolicy) - Method in class alluxio.resource.DynamicResourcePool.Options
-
- setSequenceNumber(long) - Method in class alluxio.master.file.state.DirectoryId
-
- setSequenceNumber(long) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
optional int64 sequence_number = 2;
- setSequenceNumber(long) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
shared fields.
- setSerde(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string serde = 1;
- setSerdeBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
optional string serde = 1;
- setServerAddress(NetAddress) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- setServerAddress(NetAddress.Builder) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- setServerAddress(NetAddress) - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- setServerAddress(NetAddress.Builder) - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- setServerAddress(NetAddress) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- setServerAddress(NetAddress.Builder) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- setServerAddress(NetAddress) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- setServerAddress(NetAddress.Builder) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- setServerInfo(int, QuorumServerInfo) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- setServerInfo(int, QuorumServerInfo.Builder) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- setServerObserver(StreamObserver<SaslMessage>) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
-
Sets the server's Sasl stream.
- setServerState(QuorumServerState) - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
- setServerType(FileSystemBase.ServerType) - Method in class alluxio.fsmaster.BenchStandaloneGrpcServer
-
- setServiceType(ServiceType) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
The purpose of this field is to make grpc service on standby masters work without
making client changes and keeps backwards compatibility.
- setSetAcl(File.SetAclEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- setSetAcl(File.SetAclEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
- setSetAttribute(File.SetAttributeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- setSetAttribute(File.SetAttributeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
- setSetBlocks(int, long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
Overwrite the blocks list
- setSetTaskPoolSizeCommand(SetTaskPoolSizeCommand) - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- setSetTaskPoolSizeCommand(SetTaskPoolSizeCommand.Builder) - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
- setShared(boolean) - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional bool shared = 7;
- setShared(boolean) - Method in class alluxio.grpc.MountPOptions.Builder
-
optional bool shared = 3;
- setShared(boolean) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional bool shared = 5;
- setShared(boolean) - Method in class alluxio.wire.MountPointInfo
-
- setShouldPersistTime(long) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setShouldPersistTime(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 should_persist_time = 27;
- setShouldPersistTime(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 should_persist_time = 28;
- setShowPermissions(boolean) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets show permissions.
- setShowPermissions(boolean) - Method in class alluxio.wire.MasterWebUIData
-
Sets show permissions.
- setSize(long) - Method in class alluxio.proxy.s3.ListPartsResult.Part
-
- setSize(Long) - Method in class alluxio.util.UnixMountInfo.Options.Builder
-
- setSize(long) - Method in class alluxio.worker.block.AllocateOptions
-
Sets the allocation size.
- setSkewed(boolean) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional bool skewed = 4;
- setSkipCache(boolean) - Method in class alluxio.master.metastore.ReadOption.Builder
-
Sets whether to skip caching.
- setSkipIfExists(boolean) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
optional bool skip_if_exists = 4;
- setSkipIfExists(boolean) - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool skipIfExists = 5;
- setSkipIfExists(boolean) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional bool skip_if_exists = 10;
- setSleepStepMs(long) - Method in class alluxio.time.SteppingThreadSleeper
-
Sets the sleep step.
- setSlotIndex(int) - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
-
Set the slot index.
- setSnapshotIndex(long) - Method in class alluxio.grpc.SnapshotData.Builder
-
optional int64 snapshotIndex = 2;
- setSnapshotIndex(long) - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional int64 snapshotIndex = 2;
- setSnapshotInfo(SnapshotMetadata) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- setSnapshotInfo(SnapshotMetadata.Builder) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- setSnapshotInfoRequest(GetSnapshotInfoRequest) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- setSnapshotInfoRequest(GetSnapshotInfoRequest.Builder) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- setSnapshotInfoResponse(GetSnapshotInfoResponse) - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- setSnapshotInfoResponse(GetSnapshotInfoResponse.Builder) - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- setSnapshotRequest(GetSnapshotRequest) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- setSnapshotRequest(GetSnapshotRequest.Builder) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
Deprecated.
- setSnapshotTerm(long) - Method in class alluxio.grpc.SnapshotData.Builder
-
optional int64 snapshotTerm = 1;
- setSnapshotTerm(long) - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional int64 snapshotTerm = 1;
- setSortedBy(int, SortingColumn) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- setSortedBy(int, SortingColumn.Builder) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- setSource(PropertyKey, Source) - Method in class alluxio.conf.AlluxioProperties
-
Sets the source for a given key.
- setSource(String) - Method in class alluxio.grpc.ClientMetrics.Builder
-
optional string source = 1;
- setSource(String) - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string source = 2;
- setSource(String) - Method in class alluxio.grpc.Metric.Builder
-
optional string source = 2;
- setSource(String) - Method in class alluxio.master.meta.checkconf.ConfigRecord
-
- setSourceBytes(ByteString) - Method in class alluxio.grpc.ClientMetrics.Builder
-
optional string source = 1;
- setSourceBytes(ByteString) - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string source = 2;
- setSourceBytes(ByteString) - Method in class alluxio.grpc.Metric.Builder
-
optional string source = 2;
- setSourceHost(String) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- setSourceHost(String) - Method in class alluxio.grpc.CacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- setSourceHost(String) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- setSourceHostBytes(ByteString) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- setSourceHostBytes(ByteString) - Method in class alluxio.grpc.CacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- setSourceHostBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- setSourcePort(int) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int32 source_port = 3;
- setSourcePort(int) - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int32 source_port = 3;
- setSourcePort(int) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
optional int32 source_port = 3;
- setSpaceToReserve(long) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional int64 space_to_reserve = 10;
- setSpaceToReserve(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int64 space_to_reserve = 4;
- setSpec(String) - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
optional string spec = 1;
- setSpec(String) - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
optional string spec = 1;
- setSpecBytes(ByteString) - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
optional string spec = 1;
- setSpecBytes(ByteString) - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
optional string spec = 1;
- setSpecialCommandEnabled(boolean) - Method in class alluxio.fuse.options.FuseOptions.Builder
-
Enables or disabled fuse special commands.
- setSrc(String) - Method in class alluxio.grpc.Route.Builder
-
required string src = 1;
- setSrc(String) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string src = 1;
- setSrc(String) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string src = 1;
- setSrcBytes(ByteString) - Method in class alluxio.grpc.Route.Builder
-
required string src = 1;
- setSrcBytes(ByteString) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required string src = 1;
- setSrcBytes(ByteString) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required string src = 1;
- setSrcInode(Inode) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
Sets mSrcInode field.
- setSrcPath(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string srcPath = 2;
- setSrcPath(AlluxioURI) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
Sets mSrcPath field.
- setSrcPathBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string srcPath = 2;
- setStandbyMasterInfos(MasterInfo[]) - Method in class alluxio.wire.MasterWebUIMasters
-
Sets standby master infos.
- setStartAfter(String) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Start the listing after this path.
- setStartAfter(String) - Method in class alluxio.s3.ListBucketOptions
-
- setStartAfterBytes(ByteString) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
Start the listing after this path.
- setStartTime(long) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set started time.
- setStartTime(long) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional int64 startTime = 3;
- setStartTime(long) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional int64 startTime = 2;
- setStartTime(long) - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional int64 startTime = 3;
- setStartTime(long) - Method in class alluxio.master.job.AbstractJob
-
Update start time.
- setStartTime(String) - Method in class alluxio.wire.MasterInfo
-
- setStartTime(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets start time.
- setStartTimeMs(long) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int64 startTimeMs = 5;
- setStartTimeMs(long) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional int64 startTimeMs = 2;
- setStartTimeMs(long) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional int64 startTimeMs = 2;
- setStartTimeMs(long) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 startTimeMs = 7;
- setStartTimeMs(long) - Method in class alluxio.master.CoreMasterContext.Builder
-
- setStartTimeMs(long) - Method in class alluxio.master.meta.JobMasterInfo
-
- setStartTimeMs(long) - Method in class alluxio.master.meta.MasterInfo
-
- setStartTimeMs(long) - Method in class alluxio.master.meta.ProxyInfo
-
- setStartTimeMs(long) - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- setStartTimeMs(long) - Method in class alluxio.wire.AlluxioJobWorkerInfo
-
- setStartTimeMs(long) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setStartTimeMs(long) - Method in class alluxio.wire.AlluxioProxyInfo
-
- setStartTimeMs(long) - Method in class alluxio.wire.AlluxioWorkerInfo
-
- setStartTimeMs(long) - Method in class alluxio.wire.MasterInfo
-
- setStartTimeMs(long) - Method in class alluxio.wire.WorkerInfo
-
- setState(ValidationUtils.State) - Method in class alluxio.cli.ValidationTaskResult
-
Sets task state.
- setState(String) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional string state = 1;
- setState(String) - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string state = 3;
- setState(String) - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional string state = 2;
- setState(String) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional string state = 4;
- setState(NodeState) - Method in class alluxio.master.AbstractPrimarySelector
-
- setState(Job.PJobState) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 3;
- setState(Job.PJobState) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 2;
- setState(Job.PJobState) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required .alluxio.proto.journal.PJobState state = 3;
- setState(BackupState) - Method in class alluxio.wire.BackupStatus
-
Sets the backup state.
- setState(String) - Method in class alluxio.wire.WorkerInfo
-
- setStateBytes(ByteString) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional string state = 1;
- setStateBytes(ByteString) - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string state = 3;
- setStateBytes(ByteString) - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional string state = 2;
- setStateBytes(ByteString) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional string state = 4;
- setStatistics(int, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- setStatistics(int, ColumnStatisticsInfo.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- setStatistics(int, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- setStatistics(int, ColumnStatisticsInfo.Builder) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
- setStatus(CuckooStatus) - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
-
Set the status of this tag position.
- setStatus(Status) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional .alluxio.grpc.job.Status status = 4;
- setStatus(ConfigStatus) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
optional .alluxio.grpc.meta.ConfigStatus status = 3;
- setStatus(TaskStatus) - Method in class alluxio.grpc.CopyResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- setStatus(PolicyStatus) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- setStatus(PolicyStatus.Builder) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
optional .alluxio.grpc.policy.PolicyStatus status = 1;
- setStatus(Status) - Method in class alluxio.grpc.JobInfo.Builder
-
optional .alluxio.grpc.job.Status status = 4;
- setStatus(Status) - Method in class alluxio.grpc.JobProgress.Builder
-
optional .alluxio.grpc.job.Status status = 7;
- setStatus(int, Status) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
repeated .alluxio.grpc.job.Status status = 1;
- setStatus(TaskStatus) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- setStatus(TaskStatus) - Method in class alluxio.grpc.LoadResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- setStatus(TaskStatus) - Method in class alluxio.grpc.MoveResponse.Builder
-
required .alluxio.grpc.block.TaskStatus status = 1;
- setStatus(Status) - Method in class alluxio.grpc.StatusSummary.Builder
-
optional .alluxio.grpc.job.Status status = 1;
- setStatus(SyncStatus) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- setStatus(SyncStatus.Builder) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- setStatus(Status) - Method in class alluxio.job.plan.meta.PlanInfo
-
Sets the status of a job.
- setStatus(Status) - Method in class alluxio.job.wire.TaskInfo
-
- setStatus(Status.PStatus) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional .alluxio.proto.status.PStatus status = 1;
- setStatusSummary(List<JobServiceOutput.SerializableStatusSummary>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Set status summary.
- setStopwatch(Stopwatch) - Method in class alluxio.proxy.s3.S3Handler
-
Set the Stopwatch object used for recording this request's latency.
- setStopwatch(Stopwatch) - Method in class alluxio.worker.s3.S3NettyHandler
-
Set the Stopwatch object used for recording this request's latency.
- setStorage(int, String) - Method in class alluxio.grpc.StorageList.Builder
-
a lost storage path
- setStorage(Storage) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- setStorage(Storage.Builder) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- setStorageClass(String) - Method in class alluxio.proxy.s3.ListPartsResult
-
- setStorageDirs(List<UIStorageDir>) - Method in class alluxio.wire.WorkerWebUIOverview
-
Sets storage dirs.
- setStorageFormat(StorageFormat) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- setStorageFormat(StorageFormat.Builder) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- setStorageTierInfos(List<StorageTierInfo>) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets storage tier infos.
- setStorageTiers(int, String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the list of storage tiers
- setStoreType(PageStoreType) - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- setStringStats(StringColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- setStringStats(StringColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- setStringType(String) - Method in class alluxio.grpc.table.Value.Builder
-
string string_type = 3;
- setStringTypeBytes(ByteString) - Method in class alluxio.grpc.table.Value.Builder
-
string string_type = 3;
- setStringValue(String) - Method in class alluxio.grpc.MetricValue.Builder
-
optional string stringValue = 2;
- setStringValueBytes(ByteString) - Method in class alluxio.grpc.MetricValue.Builder
-
optional string stringValue = 2;
- setSubject(Subject) - Method in class alluxio.grpc.GrpcChannelBuilder
-
- setSubject(String) - Method in class alluxio.grpc.PAclEntry.Builder
-
optional string subject = 2;
- setSubject(String) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional string subject = 2;
- setSubject(String) - Method in class alluxio.security.authorization.AclEntry.Builder
-
Sets subject of this entry.
- setSubjectBytes(ByteString) - Method in class alluxio.grpc.PAclEntry.Builder
-
optional string subject = 2;
- setSubjectBytes(ByteString) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional string subject = 2;
- setSubmissionTime(long) - Method in class alluxio.grpc.CmdSummary.Builder
-
optional int64 submissionTime = 5;
- setSucceeded(boolean) - Method in interface alluxio.master.audit.AuditContext
-
Set to true if the operration associated with this
AuditContext
is allowed and
succeeds.
- setSucceeded(boolean) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
- setSucceeded(boolean) - Method in class alluxio.master.job.JobMasterAuditContext
-
- setSucceeded(boolean) - Method in class alluxio.s3.S3AuditContext
-
- setSuccess(boolean) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
TODO(gpang): remove in favor of status
- setSuccess(boolean) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
optional bool success = 1;
- setSuccess(boolean) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
TODO(gpang): remove in favor of status
- setSummary(JobServiceSummary) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- setSummary(JobServiceSummary.Builder) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
- setSummaryPerStatus(int, StatusSummary) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- setSummaryPerStatus(int, StatusSummary.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- setSyncIntervalMs(long) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional int64 syncIntervalMs = 1;
- setSyncParentNextTime(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool syncParentNextTime = 5;
- setSyncpointPath(String) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- setSyncpointPath(String) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- setSyncpointPathBytes(ByteString) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- setSyncpointPathBytes(ByteString) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
optional string syncpoint_path = 1;
- setSyncStatus(SyncStatus) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- setSyncStatus(SyncStatus.Builder) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
- setSystemStatus(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets the system status.
- setTable(int, String) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
repeated string table = 1;
- setTableInfo(TableInfo) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- setTableInfo(TableInfo.Builder) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
optional .alluxio.grpc.table.TableInfo table_info = 1;
- setTableName(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- setTableName(String) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- setTableName(String) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string table_name = 2;
- setTableName(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string table_name = 4;
- setTableName(String) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string table_name = 2;
- setTableName(String) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string table_name = 2;
- setTableName(String) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string table_name = 2;
- setTableName(String) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string table_name = 2;
- setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string table_name = 2;
- setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string table_name = 2;
- setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string table_name = 4;
- setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string table_name = 2;
- setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string table_name = 2;
- setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string table_name = 2;
- setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string table_name = 2;
- setTablesIgnored(int, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_ignored = 2;
- setTablesRemoved(int, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_removed = 5;
- setTablesUnchanged(int, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_unchanged = 3;
- setTablesUpdated(int, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
repeated string tables_updated = 4;
- setTag(String) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
required string tag = 1;
- setTagBytes(ByteString) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
required string tag = 1;
- setTargetDirectory(String) - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional string targetDirectory = 2;
- setTargetDirectoryBytes(ByteString) - Method in class alluxio.grpc.BackupPRequest.Builder
-
optional string targetDirectory = 2;
- setTargetObserver(StreamObserver<TransportMessage>) - Method in class alluxio.master.transport.GrpcMessagingConnection
-
Sets the stream observer for target.
- setTaskArgs(ByteString) - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional bytes taskArgs = 4;
- setTaskId(long) - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
optional int64 taskId = 2;
- setTaskId(long) - Method in class alluxio.grpc.RunTaskCommand.Builder
-
optional int64 taskId = 2;
- setTaskId(long) - Method in class alluxio.job.wire.TaskInfo
-
- setTaskInfo(long, TaskInfo) - Method in class alluxio.job.plan.meta.PlanInfo
-
Sets the information of a task.
- setTaskInfos(int, JobInfo) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- setTaskInfos(int, JobInfo.Builder) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- setTaskPoolSize(int) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 taskPoolSize = 5;
- setTaskPoolSize(int) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
optional int32 taskPoolSize = 1;
- setTaskPoolSize(int) - Method in class alluxio.master.job.JobMaster
-
- SetTaskPoolSizeCommand - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.SetTaskPoolSizeCommand
- SetTaskPoolSizeCommand.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.SetTaskPoolSizeCommand
- SETTASKPOOLSIZECOMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.JobCommand
-
- SetTaskPoolSizeCommandOrBuilder - Interface in alluxio.grpc
-
- setTemporary(boolean) - Method in class alluxio.client.file.CacheContext
-
- setTemporaryTokenRefreshContext(UserState) - Method in interface alluxio.underfs.UnderFileSystem
-
Sets the userState to UFS instance.
- setTempUfsPath(String) - Method in class alluxio.master.file.meta.MutableInodeFile
-
- setTempUfsPath(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string temp_ufs_path = 23;
- setTempUfsPath(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string tempUfsPath = 12;
- setTempUfsPath(String) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string temp_ufs_path = 11;
- setTempUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string temp_ufs_path = 23;
- setTempUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string tempUfsPath = 12;
- setTempUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional string temp_ufs_path = 11;
- setThreadCountIoMbps(Map<Integer, Float>) - Method in class alluxio.stress.client.ClientIOSummary
-
- setThreadCountResults(Map<Integer, ClientIOTaskResult.ThreadCountResult>) - Method in class alluxio.stress.client.ClientIOTaskResult
-
- setThreads(int, String) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
repeated string threads = 1;
- setThroughput(float) - Method in class alluxio.stress.common.GeneralBenchSummary
-
- setThroughput(List<Long>) - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
-
- setThroughputPercentiles(List<Long>) - Method in class alluxio.stress.worker.WorkerBenchSummary
-
- setThroughputPercentiles(List<Long>) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- setTid(Long) - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
-
- setTier(int) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
This is only applicable for block write.
- setTier(int) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
optional int32 tier = 3;
- setTier(int) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
This is only applicable for block write.
- setTier(String) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string tier = 2;
- setTierAlias(String) - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string tierAlias = 3;
- setTierAlias(String) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string tierAlias = 1;
- setTierAlias(String) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the alias of the target tier
- setTierAlias(String) - Method in class alluxio.wire.BlockLocation
-
- setTierAliasBytes(ByteString) - Method in class alluxio.grpc.BlockLocation.Builder
-
optional string tierAlias = 3;
- setTierAliasBytes(ByteString) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
optional string tierAlias = 1;
- setTierAliasBytes(ByteString) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the alias of the target tier
- setTierBytes(ByteString) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string tier = 2;
- setTierCapacity(Map<String, Capacity>) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setTierCapacity(Map<String, Capacity>) - Method in class alluxio.wire.AlluxioWorkerInfo
-
- setTierPaths(Map<String, List<String>>) - Method in class alluxio.wire.AlluxioWorkerInfo
-
- setTiers(int, long) - Method in class alluxio.grpc.TierList.Builder
-
repeated int64 tiers = 1;
- setTimeExpression(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string timeExpression = 4;
- setTimeExpressionBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
optional string timeExpression = 4;
- setTimeout(long) - Method in class alluxio.network.netty.NettyRPCContext
-
- setTimeoutDuration(long) - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- setTimeoutMs(long) - Method in class alluxio.util.WaitForOptions
-
- setTimeoutThreads(int) - Method in class alluxio.client.file.cache.store.PageStoreOptions
-
- setTimeSeriesMetrics(List<TimeSeries>) - Method in class alluxio.wire.MasterWebUIMetrics
-
- setTimeToFirstBytePerThread(Map<Integer, Map<String, SummaryStatistics>>) - Method in class alluxio.stress.client.ClientIOTaskResult
-
- setTitle(List<String>) - Method in class alluxio.stress.graph.Graph
-
- setTotal(long) - Method in class alluxio.wire.Capacity
-
- setTotalBytesReadDomainSocket(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes read from domain socket.
- setTotalBytesReadDomainSocketThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes read domain socket throughput.
- setTotalBytesReadRemote(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes read remote.
- setTotalBytesReadRemoteThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes read remote throughput.
- setTotalBytesReadUfs(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes read ufs.
- setTotalBytesReadUfsThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes read ufs throughput.
- setTotalBytesWrittenDomainSocket(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes written through domain socket.
- setTotalBytesWrittenDomainSocketThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes written domain socket throughput.
- setTotalBytesWrittenRemote(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes written remote.
- setTotalBytesWrittenRemoteThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes written remote throughput.
- setTotalBytesWrittenUfs(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes written ufs.
- setTotalBytesWrittenUfsThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets total bytes written ufs throughput.
- setTotalCapacityOnTiers(Map<String, Long>) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Get capacity by tiers.
- setTotalListings(long) - Method in class alluxio.master.file.contexts.ListStatusContext
-
Set the total number of listings in this call,
this should be -1 if a recursive listing.
- setTotalPath(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets total path.
- setTransferId(String) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
required string transferId = 1;
- setTransferId(String) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
required string transferId = 1;
- setTransferIdBytes(ByteString) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
required string transferId = 1;
- setTransferIdBytes(ByteString) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
required string transferId = 1;
- setTransformations(int, Transformation) - Method in class alluxio.grpc.table.Partition.Builder
-
The latest transformation is in the back of the list.
- setTransformations(int, Transformation.Builder) - Method in class alluxio.grpc.table.Partition.Builder
-
The latest transformation is in the back of the list.
- setTransMsg(TransferLeaderMessage) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- setTransMsg(TransferLeaderMessage.Builder) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
- setTs(long) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
the timestamp in nanoseconds when this FileStatus is refreshed
- setTtl(FileSystem, AlluxioURI, long, TtlAction) - Static method in class alluxio.cli.fs.command.FileSystemCommandUtils
-
Sets a new TTL value or unsets an existing TTL value for file at path.
- setTtl(long) - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 ttl = 15;
- setTtl(long) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional int64 ttl = 2;
- setTtl(long) - Method in class alluxio.master.file.meta.MutableInode
-
- setTtl(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 ttl = 13;
- setTtl(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 ttl = 13;
- setTtl(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional int64 ttl = 4;
- setTtl(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 ttl = 12;
- setTtl(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 ttl = 4;
- setTtl(long) - Method in class alluxio.wire.FileInfo
-
- setTtlAction(TtlAction) - Method in class alluxio.grpc.FileInfo.Builder
-
optional .alluxio.grpc.TtlAction ttlAction = 22;
- setTtlAction(TtlAction) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
optional .alluxio.grpc.TtlAction ttlAction = 3;
- setTtlAction(TtlAction) - Method in class alluxio.master.file.meta.MutableInode
-
- setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
- setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
- setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
- setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
- setTtlAction(TtlAction) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.grpc.TtlAction ttl_action = 5;
- setTtlAction(TtlAction) - Method in class alluxio.wire.FileInfo
-
- setTtlCheckIntervalSeconds(long) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setTtlEnabled(boolean) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setTtlThresholdSeconds(long) - Method in class alluxio.client.file.cache.CacheManagerOptions
-
- setTxId(long) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
optional int64 tx_id = 2;
- setType(String) - Method in class alluxio.grpc.JobDescription.Builder
-
required string type = 1;
- setType(JobType) - Method in class alluxio.grpc.JobInfo.Builder
-
optional .alluxio.grpc.job.JobType type = 8;
- setType(PAclEntryType) - Method in class alluxio.grpc.PAclEntry.Builder
-
optional .alluxio.grpc.file.PAclEntryType type = 1;
- setType(String) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string type = 3;
- setType(TableInfo.TableType) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
- setType(RequestType) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional .alluxio.grpc.block.RequestType type = 1;
- setType(String) - Method in class alluxio.job.JobDescription.Builder
-
set job type.
- setType(Protocol.ReadResponse.Type) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
- setType(Protocol.RequestType) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
optional .alluxio.proto.dataserver.RequestType type = 1;
- setType(Acl.AclEntryType) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional .alluxio.proto.shared.AclEntryType type = 1;
- setType(AclEntryType) - Method in class alluxio.security.authorization.AclEntry.Builder
-
Sets the type of the entry.
- setTypeBytes(ByteString) - Method in class alluxio.grpc.JobDescription.Builder
-
required string type = 1;
- setTypeBytes(ByteString) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string type = 3;
- setUdbConnectionUri(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_connection_uri = 2;
- setUdbConnectionUriBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_connection_uri = 2;
- setUdbDbName(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_db_name = 3;
- setUdbDbNameBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_db_name = 3;
- setUdbType(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_type = 1;
- setUdbTypeBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string udb_type = 1;
- setUfsCapacity(Capacity) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setUfsCapacityBytes(long) - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 ufsCapacityBytes = 3 [default = -1];
- setUfsCapacityBytes(long) - Method in class alluxio.wire.MountPointInfo
-
- setUfsFallbackEnabled(boolean) - Method in class alluxio.client.file.DoraCacheFileSystem
-
Dora Cache file system implementation.
- setUfsFallbackEnabled(boolean) - Method in class alluxio.client.file.options.FileSystemOptions.Builder
-
- setUfsFileStatus(UfsFileStatus) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- setUfsFileStatus(UfsFileStatus.Builder) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
- setUfsFileSystemOptions(UfsFileSystemOptions) - Method in class alluxio.client.file.options.FileSystemOptions.Builder
-
- setUfsFingerprint(String) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsFingerprint = 26;
- setUfsFingerprint(String) - Method in class alluxio.master.file.contexts.SetAttributeContext
-
Sets ufs fingerprint.
- setUfsFingerprint(String) - Method in class alluxio.master.file.meta.MutableInode
-
- setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional string ufs_fingerprint = 5;
- setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string ufs_fingerprint = 18;
- setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string ufs_fingerprint = 10;
- setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string ufs_fingerprint = 15;
- setUfsFingerprint(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string ufs_fingerprint = 11;
- setUfsFingerprint(String) - Method in class alluxio.wire.FileInfo
-
- setUfsFingerprintBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsFingerprint = 26;
- setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
optional string ufs_fingerprint = 5;
- setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional string ufs_fingerprint = 18;
- setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
optional string ufs_fingerprint = 10;
- setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional string ufs_fingerprint = 15;
- setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional string ufs_fingerprint = 11;
- setUfsFullPath(String) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string ufs_full_path = 8;
- setUfsFullPath(AlluxioURI) - Method in class alluxio.underfs.UfsStatus
-
- setUfsFullPathBytes(ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
-
optional string ufs_full_path = 8;
- setUfsInfo(UfsInfo) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- setUfsInfo(UfsInfo.Builder) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
- setUfsLength(long) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional int64 ufsLength = 1;
- setUfsLocations(int, WorkerNetAddress) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- setUfsLocations(int, WorkerNetAddress.Builder) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
- setUfsLocations(List<String>) - Method in class alluxio.wire.FileBlockInfo
-
- setUfsManager(MasterUfsManager) - Method in class alluxio.master.CoreMasterContext.Builder
-
- setUfsMode(UfsPMode) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
- setUfsMode(File.UfsMode) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
- setUfsMode(Supplier<JournalContext>, AlluxioURI, UfsMode) - Method in class alluxio.underfs.MasterUfsManager
-
Set the operation mode the given physical ufs.
- setUfsOps(Map<String, Map<String, Long>>) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets ufs ops.
- setUfsOpsSaved(Map<String, Map<String, Long>>) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets ufs saved ops.
- setUfsPath(String) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setUfsPath(String) - Method in class alluxio.grpc.Block.Builder
-
optional string ufs_path = 3;
- setUfsPath(String) - Method in class alluxio.grpc.File.Builder
-
optional string ufs_path = 2;
- setUfsPath(String) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsPath = 4;
- setUfsPath(String) - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of the under file system
- setUfsPath(String) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
the ufs path
- setUfsPath(String) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string ufs_path = 1;
- setUfsPath(String) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional string ufs_path = 1;
- setUfsPath(String) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string ufs_path = 2;
- setUfsPath(String) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
optional string ufsPath = 1;
- setUfsPath(String) - Method in class alluxio.wire.FileInfo
-
- setUfsPathBytes(ByteString) - Method in class alluxio.grpc.Block.Builder
-
optional string ufs_path = 3;
- setUfsPathBytes(ByteString) - Method in class alluxio.grpc.File.Builder
-
optional string ufs_path = 2;
- setUfsPathBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsPath = 4;
- setUfsPathBytes(ByteString) - Method in class alluxio.grpc.MountPRequest.Builder
-
the path of the under file system
- setUfsPathBytes(ByteString) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
the ufs path
- setUfsPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
optional string ufs_path = 1;
- setUfsPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
optional string ufs_path = 1;
- setUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional string ufs_path = 2;
- setUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
optional string ufsPath = 1;
- setUfsReadOptions(UfsReadOptions) - Method in class alluxio.grpc.CopyRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- setUfsReadOptions(UfsReadOptions.Builder) - Method in class alluxio.grpc.CopyRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- setUfsReadOptions(UfsReadOptions) - Method in class alluxio.grpc.MoveRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- setUfsReadOptions(UfsReadOptions.Builder) - Method in class alluxio.grpc.MoveRequest.Builder
-
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
- setUfsReadSize(Map<String, String>) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets ufs read size.
- setUfsReadWorkerLocation(WorkerNetAddress) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- setUfsReadWorkerLocation(WorkerNetAddress.Builder) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
If specified and the blocks are not cached in any worker,
the data will be read and cached to the certain worker.
- setUfsResource(CloseableResource<UnderFileSystem>) - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
-
- setUfsStatus(UfsStatus) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- setUfsStatus(UfsStatus.Builder) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
- setUfsStatus(int, UfsStatus) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- setUfsStatus(int, UfsStatus.Builder) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
- setUfsStatus(UfsStatus) - Method in class alluxio.master.file.contexts.CompleteFileContext
-
Sets ufs status.
- setUfsStatus(UfsStatus) - Method in class alluxio.master.file.contexts.CreateDirectoryContext
-
- setUfsStatus(UfsStatus) - Method in class alluxio.master.file.contexts.LoadMetadataContext
-
- setUfsStringLocations(int, String) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
repeated string ufsStringLocations = 4;
- setUfsType(String) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsType = 35;
- setUfsType(String) - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsType = 2;
- setUfsType(String) - Method in class alluxio.wire.FileInfo
-
- setUfsType(String) - Method in class alluxio.wire.MountPointInfo
-
- setUfsTypeBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
optional string ufsType = 35;
- setUfsTypeBytes(ByteString) - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsType = 2;
- setUfsUri(String) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
required string ufsUri = 1;
- setUfsUri(String) - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsUri = 1;
- setUfsUri(String) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
optional string ufsUri = 1;
- setUfsUri(String) - Method in class alluxio.wire.MountPointInfo
-
- setUfsUriBytes(ByteString) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
required string ufsUri = 1;
- setUfsUriBytes(ByteString) - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional string ufsUri = 1;
- setUfsUriBytes(ByteString) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
optional string ufsUri = 1;
- setUfsUsedBytes(long) - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional int64 ufsUsedBytes = 4 [default = -1];
- setUfsUsedBytes(long) - Method in class alluxio.wire.MountPointInfo
-
- setUfsWriteSize(Map<String, String>) - Method in class alluxio.wire.MasterWebUIMetrics
-
Sets ufs write size.
- setUgi(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
-
Sets mUgi field.
- setUgi(String) - Method in class alluxio.master.job.JobMasterAuditContext
-
Sets mUgi field.
- setUgi(String) - Method in class alluxio.s3.S3AuditContext
-
Sets mUgi field.
- setUnchecked(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool unchecked = 3;
- setUnderFileSystem(UnderFileSystem) - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
-
- setUnfinishedTasks(int) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int32 unfinishedTasks = 7;
- setUniqueBlockCount(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets unique block count.
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ActionInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupPStatus.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Block.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockIdList.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockLocation.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockStatus.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BuildVersion.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CacheRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CacheResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Chunk.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClientMetrics.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CmdProgress.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CmdStatusBlock.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CmdSummary.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Command.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ConfigProperties.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ConfigProperty.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CopyRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CopyResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DeletePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DeletePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DeletePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
-
Deprecated.
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
Deprecated.
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ErrorInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ExistsPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ExistsPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ExistsPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.File.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileBlockInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileFailure.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemCommand.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FsOpPId.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
-
Deprecated.
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
Deprecated.
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
Deprecated.
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.InconsistentProperties.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.InconsistentProperty.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobCommand.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobDescription.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobProgress.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobStatusBlock.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobUnused.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
Deprecated.
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListAllPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadFileFailure.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadFileRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadFileResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterVersion.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Metric.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricValue.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPointInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveBlockResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NetAddress.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PAcl.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PAclEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PersistFile.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PMode.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PolicyInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PolicyStatus.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyStatus.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReadRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReadResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterCommand.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RenamePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RenamePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RenamePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RetryInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Route.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RouteFailure.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunTaskCommand.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SaslMessage.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAclPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAclPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAttributePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SnapshotData.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StatusSummary.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopJobPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopJobPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StorageList.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Constraint.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Database.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Date.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Decimal.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Domain.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.FieldSchema.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.FileStatistics.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Layout.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.LayoutSpec.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Partition.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.PartitionSpec.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Range.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.RangeSet.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Schema.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TableInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Transformation.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Value.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TierList.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransportMessage.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsFileStatus.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsStatus.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UnmountPOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UnmountPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UnmountPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
Deprecated.
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
Deprecated.
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerIdentity.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
-
- setUnscaled(ByteString) - Method in class alluxio.grpc.table.Decimal.Builder
-
required bytes unscaled = 2;
- setUnused0(int, JobUnused) - Method in class alluxio.grpc.JobInfo.Builder
-
Around for backwards compatibility
- setUnused0(int, JobUnused.Builder) - Method in class alluxio.grpc.JobInfo.Builder
-
Around for backwards compatibility
- setUnused1(String) - Method in class alluxio.grpc.JobInfo.Builder
-
formerly result
- setUnused1Bytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
-
formerly result
- setup() - Method in class alluxio.dora.meta.DoraMetaBench.Db
-
- setup() - Method in class alluxio.fsmaster.FileSystemBench.AlluxioBenchThreadState
-
- setup(FileSystemBench.FileSystem, ThreadParams) - Method in class alluxio.fsmaster.FileSystemBench.AsyncBenchThreadState
-
- setup(FileSystemBench.FileSystem, ThreadParams) - Method in class alluxio.fsmaster.FileSystemBench.BlockingBenchThreadState
-
- setup() - Method in class alluxio.fsmaster.FileSystemBench.FileSystem
-
- setup() - Method in class alluxio.fsmaster.FileSystemBench.HadoopBenchThreadState
-
- setup(FileSystemBench.FileSystem) - Method in class alluxio.fsmaster.FileSystemBench.ThreadState
-
- setup() - Method in class alluxio.fsmaster.FileSystemMasterBench.FileSystem
-
- setup() - Method in class alluxio.fsmaster.FileSystemMasterBench.ThreadState
-
- setup() - Method in class alluxio.inode.InodeBenchRead.Db
-
- setup() - Method in class alluxio.inode.InodeBenchWrite.Db
-
- setup(InodeBenchWrite.Db) - Method in class alluxio.inode.InodeBenchWrite.ThreadState
-
- setup() - Method in class alluxio.inode.RocksBenchRead.Db
-
- setup() - Method in class alluxio.inode.RocksBenchRead.ThreadState
-
- setup() - Method in class alluxio.inode.RocksBenchReadWrite.Db
-
- setup(RocksBenchReadWrite.Db, ThreadParams) - Method in class alluxio.inode.RocksBenchReadWrite.ThreadState
-
- setup() - Method in class alluxio.inode.RocksBenchWrite.Db
-
- setup(ThreadParams) - Method in class alluxio.inode.RocksBenchWrite.ThreadState
-
- setup() - Method in class alluxio.invalidation.cache.InvalidationSyncCacheBench.ThreadState
-
- setup() - Method in class alluxio.snapshot.SnapshotBench.Snapshot
-
- setUpdateCheckEnabled(boolean) - Method in class alluxio.fuse.options.FuseOptions.Builder
-
Enables or disables update check.
- setUpdateInode(File.UpdateInodeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- setUpdateInode(File.UpdateInodeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
- setUpdateInodeDirectory(File.UpdateInodeDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- setUpdateInodeDirectory(File.UpdateInodeDirectoryEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
- setUpdateInodeFile(File.UpdateInodeFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- setUpdateInodeFile(File.UpdateInodeFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
- setUpdateLastAccessTime(boolean) - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional bool updateLastAccessTime = 4 [default = true];
- setUpdateTimestamps(boolean) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional bool updateTimestamps = 4 [default = true];
- setUpdateUfsMode(File.UpdateUfsModeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- setUpdateUfsMode(File.UpdateUfsModeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
- setupFuseFileSystem(AlluxioJniFuseFileSystem) - Method in class alluxio.fuse.AlluxioFuse
-
- setUploadId(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
-
- setUploadId(String) - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
-
- setUploadId(String) - Method in class alluxio.proxy.s3.ListPartsResult
-
- setUploads(List<ListMultipartUploadsResult.Upload>) - Method in class alluxio.proxy.s3.ListMultipartUploadsResult
-
- setupTest() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Sets up corresponding directories for tests.
- setUptime(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets uptime.
- setUptimeDuration(long) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set time running.
- setUpTimeMs(long) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int64 upTimeMs = 6;
- setUptimeMs(long) - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- setUptimeMs(long) - Method in class alluxio.wire.AlluxioJobWorkerInfo
-
- setUptimeMs(long) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setUptimeMs(long) - Method in class alluxio.wire.AlluxioProxyInfo
-
- setUptimeMs(long) - Method in class alluxio.wire.AlluxioWorkerInfo
-
- setupTrial() - Method in class alluxio.invalidation.cache.InvalidationSyncCacheBench.FileStructure
-
- setUri(String) - Method in class alluxio.grpc.UfsInfo.Builder
-
optional string uri = 1;
- setUri(AlluxioURI) - Method in class alluxio.wire.UfsInfo
-
- setUriBytes(ByteString) - Method in class alluxio.grpc.UfsInfo.Builder
-
optional string uri = 1;
- setUriValidationEnabled(boolean) - Method in class alluxio.ClientContext
-
- setUsageOnTiers(List<UIUsageOnTier>) - Method in class alluxio.wire.WorkerWebUIOverview
-
Sets usage on tiers.
- setUsed(long) - Method in class alluxio.wire.Capacity
-
- setUsedBytes(long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
-
optional int64 usedBytes = 6;
- setUsedBytes(long) - Method in class alluxio.grpc.WorkerInfo.Builder
-
optional int64 usedBytes = 6;
- setUsedBytes(long) - Method in class alluxio.wire.BlockMasterInfo
-
- setUsedBytes(long) - Method in class alluxio.wire.WorkerInfo
-
- setUsedBytes(String) - Method in class alluxio.wire.WorkerWebUIOverview
-
Sets used bytes.
- setUsedBytesOnTier(long) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the space used in bytes on the target tier
- setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.BlockMasterInfo
-
- setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.WorkerInfo
-
- setUsedCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets used capacity.
- setUsedCapacityOnTiers(Map<String, Long>) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set used capacity by tiers.
- setUseMultipartUpload(boolean) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool useMultipartUpload = 17;
- setUser(String) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
optional string user = 4;
- setUser(String) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The client does not need to set this.
- setUser(String) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional string user = 6;
- setUser(String) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional string user = 5;
- setUser(String) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional string user = 6;
- setUserActions(int, Acl.NamedAclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- setUserActions(int, Acl.NamedAclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
-
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
- setUseRaftJournal(boolean) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set if Alluxio uses raft journal.
- setUserBytes(ByteString) - Method in class alluxio.grpc.UfsReadOptions.Builder
-
optional string user = 4;
- setUserBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
-
The client does not need to set this.
- setUserBytes(ByteString) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
optional string user = 6;
- setUserBytes(ByteString) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
optional string user = 5;
- setUserBytes(ByteString) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
optional string user = 6;
- setUseReservedSpace(boolean) - Method in class alluxio.worker.block.AllocateOptions
-
Sets value for whether this allocation can use reserved space.
- setUserGroup(AlluxioURI, long, long) - Method in interface alluxio.fuse.auth.AuthPolicy
-
Sets user and group based on user group input.
- setUserGroup(AlluxioURI, long, long) - Method in class alluxio.fuse.auth.CustomAuthPolicy
-
- setUserGroup(AlluxioURI, long, long) - Method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
-
- setUserGroupIfNeeded(AlluxioURI) - Method in interface alluxio.fuse.auth.AuthPolicy
-
Sets user and group based on authentication policy.
- setUserGroupIfNeeded(AlluxioURI) - Method in class alluxio.fuse.auth.CustomAuthPolicy
-
- setUserGroupIfNeeded(AlluxioURI) - Method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
-
- setUserGroupIfNeeded(AlluxioURI) - Method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
-
- setUserState(UserState) - Method in class alluxio.master.CoreMasterContext.Builder
-
- setUseZookeeper(boolean) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set if zookeeper is running.
- setUuid(String) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional string uuid = 3;
- setUuid(String) - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
uuid of its open file handle
- setUuidBytes(ByteString) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
optional string uuid = 3;
- setUuidBytes(ByteString) - Method in class alluxio.grpc.CreateFilePResponse.Builder
-
uuid of its open file handle
- setValue(String) - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string value = 3;
- setValue(BlockIdList) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- setValue(BlockIdList.Builder) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
-
optional .alluxio.grpc.block.BlockIdList value = 2;
- setValue(double) - Method in class alluxio.grpc.Metric.Builder
-
optional double value = 4;
- setValue(String) - Method in class alluxio.master.meta.checkconf.ConfigRecord
-
- setValue(double) - Method in class alluxio.metrics.Metric
-
Set the metric value.
- setValue(String) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string value = 2;
- setValue(String) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string value = 3;
- setValueBytes(ByteString) - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string value = 3;
- setValueBytes(ByteString) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
-
optional string value = 2;
- setValueBytes(ByteString) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
-
required string value = 3;
- setValues(int, String) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
-
repeated string values = 1;
- setValues(int, String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
list of string values for each partition column
- setValues(Map<Optional<String>, List<String>>) - Method in class alluxio.wire.InconsistentProperty
-
- setValueValidationFunction(Function<Object, Boolean>) - Method in class alluxio.conf.PropertyKey.Builder
-
- setVerbose(boolean) - Method in class alluxio.grpc.JobProgressPOptions.Builder
-
optional bool verbose = 2;
- setVerificationEnabled(boolean) - Method in class alluxio.master.job.CopyJob
-
Enable verification.
- setVerificationEnabled(boolean) - Method in class alluxio.master.job.LoadJob
-
Enable verification.
- setVerificationEnabled(boolean) - Method in class alluxio.master.job.MoveJob
-
Enable verification.
- setVerify(boolean) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional bool verify = 2;
- setVerify(boolean) - Method in class alluxio.grpc.LoadJobPOptions.Builder
-
optional bool verify = 2;
- setVerify(boolean) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional bool verify = 2;
- setVerify(boolean) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
-
required bool verify = 5;
- setVerify(boolean) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
-
required bool verify = 4;
- setVerify(boolean) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
-
required bool verify = 5;
- setVersion(String) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set Alluxio version.
- setVersion(String) - Method in class alluxio.grpc.BuildVersion.Builder
-
the project version
- setVersion(long) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
-
optional int64 version = 1;
- setVersion(BuildVersion) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.JobMasterStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- setVersion(BuildVersion) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional .alluxio.grpc.BuildVersion version = 8;
- setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional .alluxio.grpc.BuildVersion version = 8;
- setVersion(String) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string version = 7;
- setVersion(String) - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string version = 2;
- setVersion(BuildVersion) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- setVersion(BuildVersion) - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 5;
- setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.ProxyStatus.Builder
-
optional .alluxio.grpc.BuildVersion version = 5;
- setVersion(BuildVersion) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
-
optional .alluxio.grpc.BuildVersion version = 4;
- setVersion(BuildVersion) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.BuildVersion version = 3;
- setVersion(String) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string version = 4;
- setVersion(long) - Method in class alluxio.grpc.table.Partition.Builder
-
optional int64 version = 4;
- setVersion(long) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 version = 10;
- setVersion(int) - Method in class alluxio.grpc.WorkerIdentity.Builder
-
version of the definition of the opaque identifier
- setVersion(BuildVersion) - Method in class alluxio.master.meta.JobMasterInfo
-
- setVersion(String) - Method in class alluxio.master.meta.MasterInfo
-
- setVersion(String) - Method in class alluxio.master.meta.ProxyInfo
-
- setVersion(String) - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- setVersion(String) - Method in class alluxio.wire.AlluxioJobWorkerInfo
-
- setVersion(String) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setVersion(String) - Method in class alluxio.wire.AlluxioProxyInfo
-
- setVersion(String) - Method in class alluxio.wire.AlluxioWorkerInfo
-
- setVersion(String) - Method in class alluxio.wire.MasterInfo
-
- setVersion(String) - Method in class alluxio.wire.MasterWebUIOverview
-
Sets version.
- setVersion(String) - Method in class alluxio.wire.WorkerInfo
-
- setVersion(String) - Method in class alluxio.wire.WorkerWebUIOverview
-
Sets version.
- setVersionBytes(ByteString) - Method in class alluxio.grpc.BuildVersion.Builder
-
the project version
- setVersionBytes(ByteString) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional string version = 7;
- setVersionBytes(ByteString) - Method in class alluxio.grpc.MasterVersion.Builder
-
optional string version = 2;
- setVersionBytes(ByteString) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
-
optional string version = 4;
- setVersionCreationTime(long) - Method in class alluxio.grpc.table.Partition.Builder
-
optional int64 version_creation_time = 5;
- setVersionCreationTime(long) - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional int64 version_creation_time = 11;
- setVersionId(String) - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
-
Sets the version id of deleted object.
- setVersionId(String) - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
-
Sets the version id.
- setViewingOffset(long) - Method in class alluxio.wire.MasterWebUIBrowse
-
Sets viewing offset.
- setViewingOffset(long) - Method in class alluxio.wire.MasterWebUILogs
-
Sets viewing offset.
- setViewingOffset(long) - Method in class alluxio.wire.WorkerWebUILogs
-
Sets viewing offset.
- setWebFileInfoEnabled(boolean) - Method in class alluxio.wire.MasterWebUIInit
-
Sets web file info enabled.
- setWebFileInfoEnabled(boolean) - Method in class alluxio.wire.WorkerWebUIInit
-
Sets web file info enabled.
- setWebPort(int) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set web port.
- setWebPort(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
optional int32 webPort = 8;
- setWebPort(int) - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 webPort = 4;
- setWebPort(int) - Method in class alluxio.wire.WorkerNetAddress
-
- setWebServer(WebServer) - Method in class alluxio.worker.AlluxioWorkerProcess
-
- setWhiteList(boolean) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
optional bool white_list = 2;
- setWhitelist(List<String>) - Method in class alluxio.wire.MasterWebUIConfiguration
-
Sets whitelist.
- setWhitelist(List<String>) - Method in class alluxio.wire.WorkerWebUIConfiguration
-
Sets whitelist.
- setWid(Long) - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
-
- setWorkerAddress(WorkerNetAddress) - Method in class alluxio.grpc.BlockLocation.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- setWorkerAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.BlockLocation.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
- setWorkerAddress(WorkerNetAddress) - Method in class alluxio.wire.BlockLocation
-
- setWorkerAddresses(int, NetAddress) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- setWorkerAddresses(int, NetAddress.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- setWorkerAssignPolicy(WorkerAssignPolicy) - Method in class alluxio.master.job.AbstractJob
-
Sets the worker assign policy.
- setWorkerCapacityFreePercentage(long) - Method in class alluxio.wire.WorkerWebUIMetrics
-
Sets worker capacity free percentage.
- setWorkerCapacityUsedPercentage(long) - Method in class alluxio.wire.WorkerWebUIMetrics
-
Sets worker capacity used percentage.
- setWorkerHealth(List<JobServiceOutput.SerializableWorkerHealth>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
-
Set worker health info.
- setWorkerHealths(int, JobWorkerHealth) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- setWorkerHealths(int, JobWorkerHealth.Builder) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- setWorkerHost(String) - Method in class alluxio.grpc.JobInfo.Builder
-
optional string workerHost = 12;
- setWorkerHost(String) - Method in class alluxio.job.wire.TaskInfo
-
- setWorkerHostBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
-
optional string workerHost = 12;
- setWorkerHostname(String) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
required string workerHostname = 1;
- setWorkerHostname(String) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
required string workerHostname = 1;
- setWorkerHostnameBytes(ByteString) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
required string workerHostname = 1;
- setWorkerHostnameBytes(ByteString) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
required string workerHostname = 1;
- setWorkerId(long) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the id of the worker
- setWorkerId(long) - Method in class alluxio.grpc.BlockLocation.Builder
-
optional int64 workerId = 1;
- setWorkerId(long) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
-
the id of the worker
- setWorkerId(long) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
the id of the worker
- setWorkerId(long) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
-
optional int64 workerId = 1;
- setWorkerId(long) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
-
optional int64 workerId = 1;
- setWorkerId(long) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
-
optional int64 workerId = 1;
- setWorkerId(long) - Method in class alluxio.grpc.JobWorkerHealth.Builder
-
optional int64 workerId = 1;
- setWorkerId(long) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
optional int64 workerId = 1;
- setWorkerId(long) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the id of the worker
- setWorkerId(long) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional int64 worker_id = 1;
- setWorkerId(long) - Method in class alluxio.wire.BlockLocation
-
- setWorkerInfo(UIWorkerInfo) - Method in class alluxio.wire.WorkerWebUIOverview
-
Sets worker info.
- setWorkerInfos(int, WorkerInfo) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- setWorkerInfos(int, WorkerInfo.Builder) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- setWorkerLocation(WorkerNetAddress) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
If specified, the data will be written to the certain worker
- setWorkerLocation(WorkerNetAddress.Builder) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
If specified, the data will be written to the certain worker
- setWorkerLostStorageInfo(int, WorkerLostStorageInfo) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- setWorkerLostStorageInfo(int, WorkerLostStorageInfo.Builder) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- setWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
the worker network address
- setWorkerNetAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
the worker network address
- setWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
the worker network address
- setWorkerNetAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
-
the worker network address
- setWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- setWorkerNetAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
-
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
- setWorkerPort(int) - Method in class alluxio.wire.MasterWebUIInit
-
Sets worker port.
- setWorkerProperties(Map<Integer, Map<PropertyKey, String>>) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
-
Sets worker specific properties.
- setWorkerRange(GetWorkerReportOptions.WorkerRange) - Method in class alluxio.client.block.options.GetWorkerReportOptions
-
- setWorkerRange(WorkerRange) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
- setWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioJobMasterInfo
-
- setWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
-
- setWorkerWebPort(long) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
-
optional int64 workerWebPort = 2;
- setWorkerWebPort(long) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
-
optional int64 workerWebPort = 2;
- setWorkingDirectory(Path) - Method in class alluxio.hadoop.AbstractFileSystem
-
- setWorkingDirectory(Path) - Method in class alluxio.hadoop.LocalCacheFileSystem
-
- setWriteOffset(long) - Method in class alluxio.fuse.OpenFileEntry
-
Sets the offset of the next write.
- setWriteOptions(WriteOptions) - Method in class alluxio.grpc.CopyRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- setWriteOptions(WriteOptions.Builder) - Method in class alluxio.grpc.CopyRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- setWriteOptions(WriteOptions) - Method in class alluxio.grpc.MoveRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- setWriteOptions(WriteOptions.Builder) - Method in class alluxio.grpc.MoveRequest.Builder
-
required .alluxio.grpc.block.WriteOptions write_options = 3;
- setWriteSpeedStat(IOTaskSummary.SpeedStat) - Method in class alluxio.stress.worker.IOTaskSummary
-
- setWriteTier(int) - Method in class alluxio.client.file.options.OutStreamOptions
-
Sets the write tier.
- setWriteTier(int) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional int32 writeTier = 7;
- setWriteType(WriteType) - Method in class alluxio.client.file.options.OutStreamOptions
-
- setWriteType(WritePType) - Method in class alluxio.grpc.CopyJobPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- setWriteType(WritePType) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
- setWriteType(WritePType) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
- setWriteType(WritePType) - Method in class alluxio.grpc.MoveJobPOptions.Builder
-
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
- setWriteType(WritePType) - Method in class alluxio.grpc.WriteOptions.Builder
-
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
- setWriteType(WriteType) - Method in class alluxio.master.file.contexts.CreatePathContext
-
- setXAttr(Map<String, byte[]>) - Method in class alluxio.master.file.contexts.CreatePathContext
-
- setXAttr(Map<String, byte[]>) - Method in class alluxio.master.file.meta.MutableInode
-
- setXAttr(Map<String, byte[]>, File.XAttrUpdateStrategy) - Method in class alluxio.master.file.meta.MutableInode
-
- setXAttr(Map<String, byte[]>) - Method in class alluxio.wire.FileInfo
-
- setxattrCallback(String, String, ByteBuffer, long, int) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- setXattrPropStrat(XAttrPropagationStrategy) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
- setXattrPropStrat(XAttrPropagationStrategy) - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
- setXattrUpdateStrategy(File.XAttrUpdateStrategy) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
- setXAttrUpdateStrategy(File.XAttrUpdateStrategy) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
- setZookeeperAddress(List<String>) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
-
Set zookeeper address.
- setZookeeperAddresses(int, String) - Method in class alluxio.grpc.MasterInfo.Builder
-
Empty means zookeeper is not enabled
- sFileSystemContextFactory - Static variable in class alluxio.client.file.FileSystemContext
-
- ShadowCacheManager - Interface in alluxio.client.file.cache
-
The interface represents a shadow cache which supports put/read/delete/aging operations.
- ShadowCacheType - Enum in alluxio.client.file.cache
-
This represents the different shadow cache implementations that can be instantiated.
- SHARED_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPointInfo
-
- SHARED_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPOptions
-
- SHARED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
-
- SharedGrpcDataReader - Class in alluxio.client.block.stream
-
A shared gRPC data reader that cache blocks data for multi-thread accessing.
- SharedGrpcDataReader(ReadRequest, BufferCachingGrpcDataReader) - Constructor for class alluxio.client.block.stream.SharedGrpcDataReader
-
- SharedGrpcDataReader.Factory - Class in alluxio.client.block.stream
-
- ShellBasedUnixGroupsMapping - Class in alluxio.security.group.provider
-
A simple shell-based implementation of
GroupMappingService
that exec's the
groups
shell command to fetch the group memberships of a given user.
- ShellBasedUnixGroupsMapping() - Constructor for class alluxio.security.group.provider.ShellBasedUnixGroupsMapping
-
- ShellCommand - Class in alluxio.shell
-
Object representation of a shell command.
- ShellCommand(String[]) - Constructor for class alluxio.shell.ShellCommand
-
Creates a ShellCommand object with the command to exec.
- ShellUtils - Class in alluxio.util
-
A utility class for running Unix commands.
- ShellUtils.ExitCodeException - Exception in alluxio.util
-
This is an IOException with exit code added.
- SHOULD_NOT_SYNC - Static variable in class alluxio.master.file.meta.SyncCheck
-
Sync is not needed, with no last sync time.
- SHOULD_PERSIST_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
-
- SHOULD_PERSIST_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
-
- SHOULD_SYNC - Static variable in class alluxio.master.file.meta.SyncCheck
-
Sync is needed.
- shouldAbort(int) - Method in class alluxio.rocks.RocksStore
-
Used by ongoing r/w operations to check if the operation needs to abort and yield
to the RocksDB shutdown.
- shouldGc(DynamicResourcePool<BlockMasterClient>.ResourceInternal<BlockMasterClient>) - Method in class alluxio.client.block.BlockMasterClientPool
-
- shouldGc(DynamicResourcePool<BlockWorkerClient>.ResourceInternal<BlockWorkerClient>) - Method in class alluxio.client.block.stream.BlockWorkerClientPool
-
- shouldGc(DynamicResourcePool<FileSystemMasterClient>.ResourceInternal<FileSystemMasterClient>) - Method in class alluxio.client.file.FileSystemMasterClientPool
-
- shouldGc(DynamicResourcePool<Channel>.ResourceInternal<Channel>) - Method in class alluxio.network.netty.NettyChannelPool
-
- shouldGc(DynamicResourcePool<T>.ResourceInternal<T>) - Method in class alluxio.resource.DynamicResourcePool
-
- shouldNotSyncWithTime(long) - Static method in class alluxio.master.file.meta.SyncCheck
-
Create a SyncCheck object indicating a sync is not needed due to
a recent sync.
- shouldSkipCache() - Method in class alluxio.master.metastore.ReadOption
-
- shouldSync() - Method in class alluxio.master.file.meta.LockingScheme
-
- shouldSyncPath(AlluxioURI, long, DescendantType) - Method in class alluxio.master.file.meta.UfsSyncPathCache
-
Check if sync should happen.
- shouldSyncWithTime(long) - Static method in class alluxio.master.file.meta.SyncCheck
-
Create a SyncCheck object indicating a sync is needed, given
the last sync time.
- shouldUseDisplayValue() - Method in class alluxio.conf.ConfigurationValueOptions
-
- shouldUseRawValue() - Method in class alluxio.conf.ConfigurationValueOptions
-
- showAllMembers() - Method in class alluxio.membership.EtcdMembershipManager
-
- showAllMembers() - Method in class alluxio.membership.MasterMembershipManager
-
- showAllMembers() - Method in interface alluxio.membership.MembershipManager
-
Pretty printed members and its liveness status.
- showAllMembers() - Method in class alluxio.membership.StaticMembershipManager
-
- shutdown() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Possibly initiates an orderly shutdown in which previously submitted tasks are executed, but no
new tasks will be accepted.
- shutdown() - Method in class alluxio.fsmaster.BenchStandaloneGrpcServer
-
- shutdown() - Method in class alluxio.grpc.GrpcChannel
-
Shuts down the channel.
- shutdown() - Method in class alluxio.grpc.GrpcServer
-
Shuts down the server.
- shutdown() - Method in class alluxio.master.AlluxioExecutorService
-
- shutdown() - Method in class alluxio.metrics.InstrumentedExecutorService
-
- shutdown() - Static method in class alluxio.proxy.s3.MultipartUploadCleaner
-
Shutdown cleaner.
- shutdown() - Method in class alluxio.util.executor.ControllableScheduler
-
- shutdown() - Method in class alluxio.worker.dora.DoraOpenFileHandleContainer
-
Wakeup the current thread and ask it to stop.
- shutdownAndAwaitTermination(ExecutorService) - Static method in class alluxio.util.executor.ExecutorServiceUtils
-
ShutdownAndAwaitTermination with default timeout.
- shutdownAndAwaitTermination(ExecutorService, long) - Static method in class alluxio.util.executor.ExecutorServiceUtils
-
Gracefully shutdown ExecutorService method.
- shutdownAndAwaitTermination(ExecutorService, long) - Static method in class alluxio.util.ThreadUtils
-
From https://docs.oracle.com/javase/7/docs/api/java/util/concurrent/ExecutorService.html
The following method shuts down an ExecutorService in two phases, first by calling shutdown to
reject incoming tasks, and then calling shutdownNow, if necessary, to cancel any lingering
tasks.
- shutdownNow() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Possibly attempts to cancel and/or stop all tasks, and reject all subsequently submitted tasks.
- shutdownNow() - Method in class alluxio.master.AlluxioExecutorService
-
- shutdownNow() - Method in class alluxio.metrics.InstrumentedExecutorService
-
- shutdownNow() - Method in class alluxio.util.executor.ControllableScheduler
-
- signalLosePrimacy() - Method in class alluxio.master.journal.ufs.UfsJournal
-
Notifies this journal that it is no longer primary.
- signalNewSnapshot() - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
-
Signal to the StateMachineStorage that a new snapshot was taken.
- SignatureInfo - Class in alluxio.s3.signature
-
Signature and related information.
- SignatureInfo(SignatureInfo.Version, String, String, String, String, String, String, String, boolean) - Constructor for class alluxio.s3.signature.SignatureInfo
-
- SignatureInfo.Version - Enum in alluxio.s3.signature
-
Signature version.
- SIMPLE_VALUE - Static variable in enum alluxio.grpc.ChannelAuthenticationScheme
-
SIMPLE = 1;
- SimpleAuthenticationProvider - Class in alluxio.security.authentication.plain
-
An authentication provider implementation that allows arbitrary combination of username and
password including empty strings.
- SimpleAuthenticationProvider() - Constructor for class alluxio.security.authentication.plain.SimpleAuthenticationProvider
-
- SimpleCuckooTable - Class in alluxio.client.file.cache.cuckoofilter
-
A simple cuckoo table.
- SimpleCuckooTable(BitSet, int, int, int) - Constructor for class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
-
Create a single cuckoo table on given bit set.
- SimpleFuseStreamFactory - Class in alluxio.fuse.file
-
- SimpleFuseStreamFactory(FileSystem, AuthPolicy) - Constructor for class alluxio.fuse.file.SimpleFuseStreamFactory
-
- SimpleInodeLockList - Class in alluxio.master.file.meta
-
A simple inode lock list.
- SimpleInodeLockList(InodeLockManager, boolean) - Constructor for class alluxio.master.file.meta.SimpleInodeLockList
-
Creates a new empty lock list.
- SimpleJobStatusBlock - Class in alluxio.job.wire
-
Class for simple job status information.
- SimpleJobStatusBlock(long, Status, String, String) - Constructor for class alluxio.job.wire.SimpleJobStatusBlock
-
Constructor.
- SimpleRateLimiter - Class in alluxio.util
-
- SimpleRateLimiter(long, Ticker) - Constructor for class alluxio.util.SimpleRateLimiter
-
Creates a simple rate limiter for testing purpose.
- SimpleService - Interface in alluxio.master.service
-
Defines a simple start/promote/demote/stop interface for interacting with simple Alluxio
master components such as the web server, metrics server, rpc server, etc...
- SimpleUserState - Class in alluxio.security.user
-
UserState implementation for the simple authentication schemes.
- SimpleUserState.Factory - Class in alluxio.security.user
-
Factory class to create the user state.
- sInfoDumpOnExitCheck - Static variable in class alluxio.ProcessUtils
-
- SINGLE_MASTER_AUTH - Static variable in interface alluxio.uri.Authority
-
- singleElementIterator(T) - Static method in class alluxio.util.CommonUtils
-
Returns an iterator that iterates on a single element.
- SingleEntryJournaled - Class in alluxio.master.journal
-
Journaled component responsible for journaling a single journal entry.
- SingleEntryJournaled() - Constructor for class alluxio.master.journal.SingleEntryJournaled
-
- SingleMasterAuthority - Class in alluxio.uri
-
A single master authority implementation.
- SingleMasterAuthority(String, int) - Constructor for class alluxio.uri.SingleMasterAuthority
-
- SingleMasterConnectDetails(InetSocketAddress) - Constructor for class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
-
- SingleMasterInquireClient - Class in alluxio.master
-
- SingleMasterInquireClient(InetSocketAddress) - Constructor for class alluxio.master.SingleMasterInquireClient
-
- SingleMasterInquireClient.SingleMasterConnectDetails - Class in alluxio.master
-
Connect details for a single master inquire client.
- SingleTagValueAggregator - Class in alluxio.metrics.aggregator
-
An aggregator that aggregates the metrics into multiple values based on a single tag of the
metric.
- SingleTagValueAggregator(String, String, String) - Constructor for class alluxio.metrics.aggregator.SingleTagValueAggregator
-
- SingleValueAggregator - Interface in alluxio.metrics
-
Interface for the aggregator that aggregates into a single value from the metrics of different
hosts.
- Sink - Interface in alluxio.metrics.sink
-
Sink consumes the records generated by the metrics source.
- SINK_REGEX - Static variable in class alluxio.metrics.MetricsSystem
-
- sinkAppend(Supplier<Set<JournalSink>>, Journal.JournalEntry) - Static method in class alluxio.master.journal.JournalUtils
-
Appends a journal entry to all the supplied journal sinks.
- sinkFlush(Supplier<Set<JournalSink>>) - Static method in class alluxio.master.journal.JournalUtils
-
Appends a flush to all the supplied journal sinks.
- SITE_CONF_DIR - Static variable in class alluxio.conf.PropertyKey.Name
-
- SITE_CONF_DIR - Static variable in class alluxio.conf.PropertyKey
-
- SITE_PROPERTIES - Static variable in class alluxio.Constants
-
- siteProperty(String) - Static method in class alluxio.conf.Source
-
Creates a site property source with the specified filename.
- size() - Method in class alluxio.client.file.MetadataCache
-
- size() - Method in interface alluxio.collections.BitSet
-
- size() - Method in class alluxio.collections.BuiltinBitSet
-
- size() - Method in class alluxio.collections.ConcurrentHashSet
-
- size() - Method in class alluxio.collections.ConcurrentIdentityHashMap
-
- size() - Method in class alluxio.collections.DelegatingSet
-
- size() - Method in interface alluxio.collections.FieldIndex
-
- size() - Method in class alluxio.collections.IndexedSet
-
- size() - Method in class alluxio.collections.LockPool
-
- size() - Method in class alluxio.collections.NonUniqueFieldIndex
-
- size() - Method in class alluxio.collections.UniqueFieldIndex
-
- size() - Method in class alluxio.collections.UnmodifiableArrayList
-
- size() - Method in class alluxio.DefaultStorageTierAssoc
-
- size() - Method in class alluxio.master.file.meta.LockedInodePath
-
- size() - Method in class alluxio.master.file.meta.TtlBucket
-
- size() - Method in interface alluxio.master.metastore.BlockMetaStore
-
- size() - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
-
- size() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
-
- size() - Method in class alluxio.master.transport.Listeners
-
- size() - Method in class alluxio.metrics.MaxReservoir
-
Returns the number of values recorded.
- size(CloseableIterator<?>) - Static method in class alluxio.resource.CloseableIterator
-
Consumes the iterator, closes it, and returns its size.
- size() - Method in class alluxio.resource.DynamicResourcePool
-
- size() - Method in interface alluxio.resource.Pool
-
- size() - Method in class alluxio.resource.ResourcePool
-
- size() - Method in interface alluxio.StorageTierAssoc
-
- size() - Method in class alluxio.StreamCache
-
- size() - Method in class alluxio.util.executor.UniqueBlockingQueue
-
- size() - Method in interface alluxio.worker.dora.DoraMetaStore
-
- size() - Method in class alluxio.worker.dora.RocksDBDoraMetaStore
-
Queries the estimated number of the records in this RocksDB.
- SizeCommand - Class in alluxio.cli.command.metadatacache
-
The metadata cache 'size' subcommand.
- SizeCommand(FileSystem, AlluxioConfiguration, String) - Constructor for class alluxio.cli.command.metadatacache.SizeCommand
-
- SizeEncoder - Class in alluxio.client.file.cache.cuckoofilter
-
A size encoder that supports encode/decode size information.
- SizeEncoder(int, int) - Constructor for class alluxio.client.file.cache.cuckoofilter.SizeEncoder
-
- SKEWED_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
-
- skip(long) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
-
- skip(long) - Method in class alluxio.client.file.PositionReadFileInStream
-
- skip(long) - Method in class alluxio.client.file.ufs.UfsFileInStream
-
- skip(long) - Method in class alluxio.file.SeekableBufferedInputStream
-
- skip(long) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
-
- skip(long) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
-
- skip(long) - Method in class alluxio.underfs.cephfs.CephInputStream
-
- skip(long) - Method in class alluxio.underfs.gcs.GCSInputStream
-
This method leverages the ability to open a stream from GCS from a given offset.
- skip(long) - Method in class alluxio.underfs.gcs.v2.GCSV2InputStream
-
This method leverages the ability to open a stream from GCS from a given offset.
- skip(long) - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
-
- skip(long) - Method in class alluxio.underfs.MultiRangeObjectInputStream
-
- skip(long) - Method in class alluxio.underfs.s3a.S3AInputStream
-
- SKIP_IF_EXISTS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileRequest
-
- SKIP_IF_EXISTS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
-
- SKIPIFEXISTS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadJobPOptions
-
- skippedSync() - Method in class alluxio.master.file.meta.SyncCheck
-
This method should be called if the sync skipped due to the existence
of a recent sync.
- sleep(Duration) - Method in interface alluxio.time.Sleeper
-
Sleeps for the given duration.
- sleep(Supplier<Duration>) - Method in interface alluxio.time.Sleeper
-
Sleeps for given duration but period wake-up by new interval supplier.
- sleep(Duration) - Method in class alluxio.time.SteppingThreadSleeper
-
- sleep(Supplier<Duration>) - Method in class alluxio.time.SteppingThreadSleeper
-
- sleep(Duration) - Method in class alluxio.time.ThreadSleeper
-
- Sleeper - Interface in alluxio.time
-
An interface for a utility which provides a sleep method.
- SLEEPING_TIMER_CLASS - Static variable in class alluxio.heartbeat.HeartbeatContext
-
- SleepingRetry - Class in alluxio.retry
-
A retry policy that uses thread sleeping for the delay.
- SleepingRetry(int) - Constructor for class alluxio.retry.SleepingRetry
-
- SleepingTimer - Class in alluxio.heartbeat
-
This class can be used for executing heartbeats periodically.
- SleepingTimer(String, Clock, Supplier<SleepIntervalSupplier>) - Constructor for class alluxio.heartbeat.SleepingTimer
-
- SleepingTimer(String, Logger, Clock, Sleeper, Supplier<SleepIntervalSupplier>) - Constructor for class alluxio.heartbeat.SleepingTimer
-
- SleepIntervalSupplier - Interface in alluxio.heartbeat
-
A policy to calculate the next interval to sleep.
- sleepMs(long) - Static method in class alluxio.util.CommonUtils
-
Sleeps for the given number of milliseconds.
- sleepMs(Logger, long) - Static method in class alluxio.util.CommonUtils
-
Sleeps for the given number of milliseconds, reporting interruptions using the given logger.
- sleepMs(long) - Static method in class alluxio.util.SleepUtils
-
Sleeps for the given number of milliseconds.
- sleepMs(Logger, long) - Static method in class alluxio.util.SleepUtils
-
Sleeps for the given number of milliseconds, reporting interruptions using the given logger.
- SleepUtils - Class in alluxio.util
-
Sleep utilities shared by all components in Alluxio.
- Slf4jSink - Class in alluxio.metrics.sink
-
A sink which outputs metric values to the metrics logger.
- Slf4jSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.Slf4jSink
-
- sliceByteBuffer(ByteBuffer, int, int) - Static method in class alluxio.util.io.BufferUtils
-
Creates a new ByteBuffer sliced from a given ByteBuffer.
- sliceByteBuffer(ByteBuffer, int) - Static method in class alluxio.util.io.BufferUtils
-
- SlidingWindowType - Enum in alluxio.client.file.cache.cuckoofilter
-
This class represents the type of sliding window.
- snapshot() - Method in interface alluxio.client.file.cache.CacheUsage
-
Creates an immutable snapshot of the current cache usage.
- snapshot() - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
-
- snapshot() - Method in class alluxio.master.meta.PathProperties
-
- snapshot(Blackhole, SnapshotBench.Snapshot) - Method in class alluxio.snapshot.SnapshotBench
-
- Snapshot() - Constructor for class alluxio.snapshot.SnapshotBench.Snapshot
-
- SnapshotBench - Class in alluxio.snapshot
-
- SnapshotBench() - Constructor for class alluxio.snapshot.SnapshotBench
-
- SnapshotBench.Snapshot - Class in alluxio.snapshot
-
- SnapshotData - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.SnapshotData
- SnapshotData.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.SnapshotData
- SnapshotDataOrBuilder - Interface in alluxio.grpc
-
- SnapshotDirStateMachineStorage - Class in alluxio.master.journal.raft
-
Simple state machine storage that can handle directories.
- SnapshotDirStateMachineStorage() - Constructor for class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
-
- SnapshotIdJournaled - Class in alluxio.master.journal.raft
-
Simple implementation to write and recover the snapshot ID when checkpointing.
- SnapshotIdJournaled() - Constructor for class alluxio.master.journal.raft.SnapshotIdJournaled
-
- SNAPSHOTINDEX_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotData
-
- SNAPSHOTINDEX_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotMetadata
-
- SNAPSHOTINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetSnapshotInfoRequest
-
Deprecated.
- SNAPSHOTINFOREQUEST_FIELD_NUMBER - Static variable in class alluxio.grpc.JournalQueryRequest
-
- SNAPSHOTINFORESPONSE_FIELD_NUMBER - Static variable in class alluxio.grpc.JournalQueryResponse
-
Deprecated.
- SnapshotMetadata - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.SnapshotMetadata
- SnapshotMetadata.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.SnapshotMetadata
- SnapshotMetadataOrBuilder - Interface in alluxio.grpc
-
- SNAPSHOTREQUEST_FIELD_NUMBER - Static variable in class alluxio.grpc.JournalQueryRequest
-
- SNAPSHOTTERM_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotData
-
- SNAPSHOTTERM_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotMetadata
-
- SOCKET_TIMEOUT_CONFIG_NAME - Static variable in class alluxio.cli.ValidationConfig
-
- SOCKET_TIMEOUT_OPTION_NAME - Static variable in class alluxio.cli.ValidationConfig
-
- SORTED_BY_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.HiveBucketProperty
-
- sortedMapToIterator(SortedMap<String, Long>, ReadOption) - Static method in class alluxio.master.metastore.heap.HeapInodeStore
-
Helper function that returns an iterator over the sorted map using the given
read options.
- SortingColumn - Class in alluxio.grpc.table.layout.hive
-
Protobuf type alluxio.grpc.table.layout.SortingColumn
- SortingColumn.Builder - Class in alluxio.grpc.table.layout.hive
-
Protobuf type alluxio.grpc.table.layout.SortingColumn
- SortingColumn.SortingOrder - Enum in alluxio.grpc.table.layout.hive
-
Protobuf enum alluxio.grpc.table.layout.SortingColumn.SortingOrder
- SortingColumnOrBuilder - Interface in alluxio.grpc.table.layout.hive
-
- sortTopologically(Set<T>) - Method in class alluxio.collections.DirectedAcyclicGraph
-
Sorts a given set of payloads topologically based on the DAG.
- Source - Class in alluxio.conf
-
The source of a configuration property.
- Source - Interface in alluxio.metrics.source
-
Source is where the metrics generated.
- Source.Type - Enum in alluxio.conf
-
Source type.
- SOURCE_FIELD_NUMBER - Static variable in class alluxio.grpc.ClientMetrics
-
- SOURCE_FIELD_NUMBER - Static variable in class alluxio.grpc.ConfigProperty
-
- SOURCE_FIELD_NUMBER - Static variable in class alluxio.grpc.Metric
-
- SOURCE_HOST_FIELD_NUMBER - Static variable in class alluxio.grpc.AsyncCacheRequest
-
- SOURCE_HOST_FIELD_NUMBER - Static variable in class alluxio.grpc.CacheRequest
-
- SOURCE_HOST_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
- SOURCE_PORT_FIELD_NUMBER - Static variable in class alluxio.grpc.AsyncCacheRequest
-
- SOURCE_PORT_FIELD_NUMBER - Static variable in class alluxio.grpc.CacheRequest
-
- SOURCE_PORT_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
-
- SPACE_TO_RESERVE_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
-
- SPACE_TO_RESERVE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
-
- sparsePrint(PrintStream) - Method in class alluxio.job.util.TimeSeries
-
Print the time series sparsely, i.e.
- SPEC_FIELD_NUMBER - Static variable in class alluxio.grpc.table.LayoutSpec
-
- SPEC_FIELD_NUMBER - Static variable in class alluxio.grpc.table.PartitionSpec
-
- specialCommandEnabled() - Method in class alluxio.fuse.options.FuseOptions
-
- SPECIFIED_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
-
- SPECIFIED_VALUE - Static variable in enum alluxio.grpc.WorkerRange
-
SPECIFIED = 4;
- specifiedMaster(InetSocketAddress) - Static method in class alluxio.master.selectionpolicy.MasterSelectionPolicy.Factory
-
Creates a MasterSelectionPolicy that selects a specified master to connect.
- SpeedStat() - Constructor for class alluxio.stress.worker.IOTaskSummary.SpeedStat
-
An empty constructor.
- spliterator() - Method in class alluxio.collections.DelegatingSet
-
- SRC_FIELD_NUMBER - Static variable in class alluxio.grpc.Route
-
- SRC_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
-
- SRC_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
-
- SRCPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.AddPolicyPOptions
-
- SshCommand - Class in alluxio.shell
-
Object representation of a remote shell command by SSH.
- SshCommand(String, String[]) - Constructor for class alluxio.shell.SshCommand
-
Creates a SshCommand instance from the remote hostname and command.
- sshExecCommandWithOutput(String, String...) - Static method in class alluxio.util.ShellUtils
-
Static method to execute a shell command remotely via ssh.
- SshValidationTask - Class in alluxio.cli
-
Task for validating SSH reachability.
- SshValidationTask(AlluxioConfiguration) - Constructor for class alluxio.cli.SshValidationTask
-
- sslContext(SslContext) - Method in class alluxio.grpc.GrpcServerBuilder
-
Sets TLS context.
- SslContextProvider - Interface in alluxio.util.network.tls
-
Interface for providing SslContext instances for TLS support.
- SslContextProvider.Factory - Class in alluxio.util.network.tls
-
Factory for creating context provider implementations.
- StackFS - Class in alluxio.fuse
-
Stack FS implements the FUSE callbacks defined by jni-fuse
without interactions with Alluxio clients/servers.
- StackFS(Path, Path) - Constructor for class alluxio.fuse.StackFS
-
- StackMain - Class in alluxio.fuse
-
Main entry for StackFS.
- StackMain() - Constructor for class alluxio.fuse.StackMain
-
- StacksServlet - Class in alluxio.web
-
Stacks servlet to display the stacks of this process.
- StacksServlet() - Constructor for class alluxio.web.StacksServlet
-
- STANDALONE_FUSE_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- STANDALONE_FUSE_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- StandardURI - Class in alluxio.uri
-
A standard URI implementation.
- StandardURI(String, Authority, String, String) - Constructor for class alluxio.uri.StandardURI
-
- StandardURI(URI, String) - Constructor for class alluxio.uri.StandardURI
-
Constructs a new URI from a base URI, but with a new path component.
- STANDBY_MASTER_GRPC_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- STANDBY_MASTER_GRPC_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- STANDBY_MASTER_METRICS_SINK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- STANDBY_MASTER_METRICS_SINK_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- STANDBY_MASTER_WEB_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- STANDBY_MASTER_WEB_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- STANDBY_VALUE - Static variable in enum alluxio.grpc.NodeState
-
STANDBY = 0;
- start(AlluxioConfiguration) - Method in class alluxio.fuse.AlluxioFuse
-
Startup the FUSE process.
- start() - Method in class alluxio.grpc.GrpcServer
-
Start serving.
- start() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Starts both master and a worker using the configurations in test conf respectively.
- start(Boolean) - Method in class alluxio.master.AbstractMaster
-
- start() - Method in class alluxio.master.AlluxioMasterProcess
-
- start() - Method in class alluxio.master.AlluxioSimpleMasterProcess
-
- start(InetSocketAddress) - Method in class alluxio.master.AlwaysStandbyPrimarySelector
-
- start() - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
-
- start(Boolean) - Method in class alluxio.master.block.DefaultBlockMaster
-
- start(Boolean) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- start(Boolean) - Method in class alluxio.master.job.JobMaster
-
- start() - Method in class alluxio.master.journal.AbstractJournalSystem
-
- start() - Method in interface alluxio.master.journal.JournalSystem
-
Starts the journal system.
- start() - Method in class alluxio.master.journal.noop.NoopJournalSystem
-
- start(InetSocketAddress) - Method in class alluxio.master.journal.raft.RaftPrimarySelector
-
- start() - Method in class alluxio.master.journal.ufs.UfsJournal
-
Starts the journal in standby mode.
- start(InetSocketAddress) - Method in class alluxio.master.journal.ufs.UfsJournalMultiMasterPrimarySelector
-
Starts the leader selection.
- start(InetSocketAddress) - Method in class alluxio.master.journal.ufs.UfsJournalSingleMasterPrimarySelector
-
- start() - Method in class alluxio.master.LocalAlluxioJobCluster
-
Starts both master and a worker using the configurations in test conf respectively.
- start() - Method in class alluxio.master.LocalAlluxioMaster
-
Starts the master.
- start() - Method in class alluxio.master.meta.DailyMetadataBackup
-
- start(Boolean) - Method in class alluxio.master.meta.DefaultMetaMaster
-
- start(Boolean) - Method in class alluxio.master.metrics.DefaultMetricsMaster
-
- start(Boolean) - Method in class alluxio.master.NoopMaster
-
- start(InetSocketAddress) - Method in interface alluxio.master.PrimarySelector
-
Starts the primary selector.
- start() - Method in class alluxio.master.scheduler.Scheduler
-
Start scheduler.
- start() - Method in class alluxio.master.service.jvmmonitor.JvmMonitorService
-
- start() - Method in class alluxio.master.service.NoopService
-
- start() - Method in class alluxio.master.service.rpc.RpcServerService
-
- start() - Method in class alluxio.master.service.rpc.RpcServerStandbyGrpcService
-
- start() - Method in interface alluxio.master.service.SimpleService
-
Starts the service.
- start() - Method in class alluxio.metrics.sink.ConsoleSink
-
- start() - Method in class alluxio.metrics.sink.CsvSink
-
- start() - Method in class alluxio.metrics.sink.GraphiteSink
-
- start() - Method in class alluxio.metrics.sink.JmxSink
-
- start() - Method in class alluxio.metrics.sink.MetricsServlet
-
- start() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
-
- start() - Method in interface alluxio.metrics.sink.Sink
-
Starts the reporter polling.
- start() - Method in class alluxio.metrics.sink.Slf4jSink
-
- start() - Method in class alluxio.multi.process.BaseMaster
-
Launches the master process.
- start() - Method in class alluxio.multi.process.ExternalProcess
-
Starts the process.
- start() - Method in class alluxio.multi.process.MultiProcessCluster
-
Starts the cluster, launching all server processes.
- start() - Method in class alluxio.multi.process.Worker
-
Launches the worker process.
- start() - Method in interface alluxio.Process
-
Starts the Alluxio process.
- start() - Method in class alluxio.proxy.AlluxioProxyProcess
-
- start(U) - Method in class alluxio.Registry
-
Starts all
Server
s in dependency order.
- start(T) - Method in interface alluxio.Server
-
Starts the Alluxio server.
- start() - Method in class alluxio.underfs.UfsIOManager
-
Start schedule thread.
- start() - Method in class alluxio.util.JvmPauseMonitor
-
Starts jvm monitor thread.
- start() - Method in class alluxio.web.WebServer
-
Starts the web server.
- start(WorkerNetAddress) - Method in class alluxio.worker.AbstractWorker
-
- start() - Method in class alluxio.worker.AlluxioJobWorkerProcess
-
- start() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- start(WorkerNetAddress) - Method in class alluxio.worker.dora.PagedDoraWorker
-
- start() - Method in class alluxio.worker.http.HttpServer
-
Starts the HTTP server.
- start(WorkerNetAddress) - Method in class alluxio.worker.JobWorker
-
- START_MS_FLAG - Static variable in class alluxio.stress.BaseParameters
-
- START_TIME_MS_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
-
START_TIME_MS = 4;
- START_TIME_MS_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
-
START_TIME_MS = 6;
- STARTAFTER_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPOptions
-
- startAuthenticatedChannel(long) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
-
Starts authentication with the server and wait until completion.
- startCommon(AlluxioConfiguration, FuseOptions, FileSystemContext) - Method in class alluxio.fuse.AlluxioFuse
-
Start common functionalities for a fuse client.
- startGrpcServer(Function<Master, Map<ServiceType, GrpcService>>) - Method in class alluxio.master.service.rpc.RpcServerService
-
- startInternal() - Method in class alluxio.master.journal.AbstractJournalSystem
-
Starts the journal system.
- startInternal() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- startInternal() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
-
- startJvmMonitorProcess() - Static method in class alluxio.fuse.AlluxioFuse
-
Starts jvm monitor process, to monitor jvm.
- startMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
-
Starts the specified master.
- startMasterComponents(boolean) - Method in class alluxio.master.AlluxioMasterProcess
-
Starts all masters, including block master, FileSystem master, and additional masters.
- startMasterComponents(boolean) - Method in class alluxio.master.AlluxioSimpleMasterProcess
-
- startMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Configures and starts the master(s).
- startMasters() - Method in class alluxio.master.LocalAlluxioCluster
-
- startMasters() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- startMasters() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- startMasters() - Method in class alluxio.multi.process.MultiProcessCluster
-
Starts all masters.
- startMetricsSystem() - Method in class alluxio.master.service.metrics.MetricsService
-
- startNewMasters(int, boolean) - Method in class alluxio.multi.process.MultiProcessCluster
-
Start a number of new master nodes.
- startProxy() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Configures and starts the proxy.
- startProxy() - Method in class alluxio.master.LocalAlluxioCluster
-
- startRejectingServer() - Method in class alluxio.master.service.rpc.RpcServerService
-
- startServer(int) - Method in class alluxio.fsmaster.BenchStandaloneGrpcServer
-
- startSinks(String) - Static method in class alluxio.metrics.MetricsSystem
-
Starts sinks specified in the configuration.
- startSinksFromConfig(MetricsConfig) - Static method in class alluxio.metrics.MetricsSystem
-
Starts sinks from a given metrics configuration.
- startsWithIncreasingByteArray(int, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
-
Checks if the given byte array contains an increasing sequence of bytes of the given
length, starting from the given value.
- STARTTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.JobMasterStatus
-
- STARTTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyHeartbeatPOptions
-
- STARTTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyStatus
-
- STARTTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
-
- STARTTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterJobMasterPOptions
-
- STARTTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterMasterPOptions
-
- STARTTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
-
- startUpload() - Method in interface alluxio.underfs.MultipartUploader
-
Initialize a multipart upload.
- startWebServer() - Method in class alluxio.master.service.web.WebServerService
-
- startWorker(int) - Method in class alluxio.multi.process.MultiProcessCluster
-
Starts the specified worker.
- startWorkers() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Configures and starts the worker(s).
- startWorkers() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- startWorkers() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- StatCommand - Class in alluxio.cli.fs.command
-
Displays the path's info.
- StatCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.StatCommand
-
- state() - Method in interface alluxio.client.file.cache.CacheManager
-
- state() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- state() - Method in class alluxio.client.file.cache.LocalCacheManager
-
- state() - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- State() - Constructor for class alluxio.master.meta.DefaultMetaMaster.State
-
- State() - Constructor for class alluxio.master.meta.PathProperties.State
-
- STATE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobMasterStatus
-
- STATE_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterVersion
-
- STATE_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyStatus
-
- STATE_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
-
- STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
-
- STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
-
- STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
-
- STATE_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
-
STATE = 7;
- stateChanged(CuratorFramework, ConnectionState) - Method in class alluxio.master.journal.ufs.UfsJournalMultiMasterPrimarySelector
-
- StateChangeJournalContext - Class in alluxio.master.journal
-
Context for correctly managing the state change lock for a wrapped journal context.
- StateChangeJournalContext(JournalContext, LockResource) - Constructor for class alluxio.master.journal.StateChangeJournalContext
-
- StateListener - Interface in alluxio.membership
-
Interface for getting callback on watch event from etcd.
- StateLockManager - Class in alluxio.master
-
Provides graceful and interruptable locking protocol for taking the state lock.
- StateLockManager() - Constructor for class alluxio.master.StateLockManager
-
Creates a new state-lock manager.
- StateLockOptions - Class in alluxio.master
-
Used to define state-lock options for taking it exclusively.
- StateLockOptions(GraceMode, long, long, long) - Constructor for class alluxio.master.StateLockOptions
-
Creates an option class that is consulted while taking a state-lock exclusively
from
StateLockManager
.
- statfs(String, Statvfs) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
Gets the filesystem statistics.
- statfs(String, Statvfs) - Method in class alluxio.fuse.StackFS
-
- statfs(String, Statvfs) - Method in interface alluxio.jnifuse.FuseFileSystem
-
- statfsCallback(String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- StaticMembershipManager - Class in alluxio.membership
-
MembershipManager configured by a static file.
- StaticWorkerMeta - Class in alluxio.master.block.meta
-
An object representation of the worker metadata.
- StaticWorkerMeta(long, WorkerNetAddress) - Constructor for class alluxio.master.block.meta.StaticWorkerMeta
-
Constructor.
- STATISTICS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsList
-
- STATISTICS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
-
- STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Layout
-
- Status - Enum in alluxio.grpc
-
Protobuf enum alluxio.grpc.job.Status
- Status - Enum in alluxio.job.wire
-
The status of a task.
- Status - Class in alluxio.proto.status
-
- Status.PStatus - Enum in alluxio.proto.status
-
exception status for a response.
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.ConfigCheckReport
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyResponse
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetPolicyStatusPResponse
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobProgress
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListAllPOptions
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileResponse
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadResponse
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveResponse
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.StatusSummary
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.SyncDatabasePResponse
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.UpdateConfigurationPResponse
-
- STATUS_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.Response
-
- StatusSummary - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.StatusSummary
- StatusSummary - Class in alluxio.job.wire
-
Status summary.
- StatusSummary(Status, long) - Constructor for class alluxio.job.wire.StatusSummary
-
- StatusSummary(StatusSummary) - Constructor for class alluxio.job.wire.StatusSummary
-
- StatusSummary.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.StatusSummary
- StatusSummaryOrBuilder - Interface in alluxio.grpc
-
- Statvfs - Class in alluxio.jnifuse.struct
-
- Statvfs(Runtime, ByteBuffer) - Constructor for class alluxio.jnifuse.struct.Statvfs
-
- SteppingThreadSleeper - Class in alluxio.time
-
A progressive sleeper that wakes up multiple times during sleep to check if the requested sleep
duration has changed, and adjust its sleep duration accordingly.
- SteppingThreadSleeper(Sleeper, Clock) - Constructor for class alluxio.time.SteppingThreadSleeper
-
- stop(Status, String, String) - Method in class alluxio.job.workflow.WorkflowExecution
-
stops future execution.
- stop() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Stops both the alluxio and underfs service threads.
- stop() - Method in class alluxio.master.AbstractMaster
-
- stop() - Method in class alluxio.master.AlluxioMasterProcess
-
- stop() - Method in class alluxio.master.AlluxioSimpleMasterProcess
-
Stops the Alluxio master server.
- stop() - Method in class alluxio.master.AlwaysStandbyPrimarySelector
-
- stop() - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
-
- stop() - Method in class alluxio.master.block.DefaultBlockMaster
-
- stop() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- stop() - Method in class alluxio.master.job.JobMaster
-
- stop() - Method in class alluxio.master.journal.AbstractJournalSystem
-
- stop() - Method in interface alluxio.master.journal.JournalSystem
-
Stops the journal system.
- stop() - Method in class alluxio.master.journal.noop.NoopJournalSystem
-
- stop() - Method in class alluxio.master.journal.raft.RaftPrimarySelector
-
- stop() - Method in class alluxio.master.journal.ufs.UfsJournalMultiMasterPrimarySelector
-
- stop() - Method in class alluxio.master.journal.ufs.UfsJournalSingleMasterPrimarySelector
-
- stop() - Method in class alluxio.master.LocalAlluxioCluster
-
- stop() - Method in class alluxio.master.LocalAlluxioJobCluster
-
Stops the alluxio job service threads.
- stop() - Method in class alluxio.master.LocalAlluxioMaster
-
Stops the master processes and cleans up client connections.
- stop() - Method in class alluxio.master.meta.DailyMetadataBackup
-
- stop() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- stop() - Method in class alluxio.master.NoopMaster
-
- stop() - Method in interface alluxio.master.PrimarySelector
-
Stops the primary selector.
- stop() - Method in class alluxio.master.scheduler.Scheduler
-
Stop scheduler.
- stop() - Method in class alluxio.master.service.jvmmonitor.JvmMonitorService
-
- stop() - Method in class alluxio.master.service.NoopService
-
- stop() - Method in class alluxio.master.service.rpc.RpcServerService
-
- stop() - Method in class alluxio.master.service.rpc.RpcServerStandbyGrpcService
-
- stop() - Method in interface alluxio.master.service.SimpleService
-
Stops the service altogether and cleans up any state left.
- stop() - Method in class alluxio.metrics.sink.ConsoleSink
-
- stop() - Method in class alluxio.metrics.sink.CsvSink
-
- stop() - Method in class alluxio.metrics.sink.GraphiteSink
-
- stop() - Method in class alluxio.metrics.sink.JmxSink
-
- stop() - Method in class alluxio.metrics.sink.MetricsServlet
-
- stop() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
-
- stop() - Method in interface alluxio.metrics.sink.Sink
-
Stops the reporter.
- stop() - Method in class alluxio.metrics.sink.Slf4jSink
-
- stop() - Method in class alluxio.multi.process.ExternalProcess
-
Stops the process.
- stop() - Method in interface alluxio.Process
-
Stops the Alluxio process, blocking until the action is completed.
- stop() - Method in class alluxio.proxy.AlluxioProxyProcess
-
- stop() - Method in class alluxio.Registry
-
Stops all
Server
s in reverse dependency order.
- stop() - Method in interface alluxio.Server
-
Stops the Alluxio server.
- stop() - Method in class alluxio.util.JvmPauseMonitor
-
Stops jvm monitor.
- stop() - Method in class alluxio.web.MasterWebServer
-
- stop() - Method in class alluxio.web.ProxyWebServer
-
- stop() - Method in class alluxio.web.WebServer
-
Shuts down the web server.
- stop() - Method in class alluxio.web.WorkerWebServer
-
- stop() - Method in class alluxio.worker.AbstractWorker
-
- stop() - Method in class alluxio.worker.AlluxioJobWorkerProcess
-
- stop() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- stop() - Method in class alluxio.worker.dora.PagedDoraWorker
-
- stop() - Method in class alluxio.worker.JobWorker
-
- stopAndJoin() - Method in class alluxio.network.RejectingServer
-
Stops the server and joins the server thread.
- stopAndRemoveMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
-
Removes master i from the cluster.
- stopCommon() - Method in class alluxio.fuse.AlluxioFuse
-
- stopFS() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Stops the alluxio filesystem's service thread only.
- stopFS() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- stopFS() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- stopGrpcServer() - Method in class alluxio.master.service.rpc.RpcServerService
-
- stopHeartBeat(WorkerInfo) - Method in class alluxio.membership.EtcdMembershipManager
-
- stopHeartBeat(WorkerInfo) - Method in class alluxio.membership.MasterMembershipManager
-
- stopHeartBeat(WorkerInfo) - Method in interface alluxio.membership.MembershipManager
-
Stop heartbeating for liveness for current worker.
- stopHeartBeat(WorkerInfo) - Method in class alluxio.membership.StaticMembershipManager
-
- stopInternal() - Method in class alluxio.master.journal.AbstractJournalSystem
-
Stops the journal system.
- stopInternal() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- stopInternal() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
-
- stopJob(JobDescription) - Method in class alluxio.client.file.DelegatingFileSystem
-
- stopJob(JobDescription) - Method in interface alluxio.client.file.FileSystem
-
Stop a job in scheduler.
- stopJob(JobDescription) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Stop a job.
- stopJob(JobDescription) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- stopJob(JobDescription) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- stopJob(StopJobPRequest, StreamObserver<StopJobPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
- stopJob(StopJobPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
- stopJob(StopJobPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
- stopJob(StopJobPRequest, StreamObserver<StopJobPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
- stopJob(StopJobPRequest, StreamObserver<StopJobPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- stopJob(JobDescription) - Method in class alluxio.master.scheduler.Scheduler
-
Stop a job.
- StopJobPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.StopJobPRequest
- StopJobPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.StopJobPRequest
- StopJobPRequestOrBuilder - Interface in alluxio.grpc
-
- StopJobPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.StopJobPResponse
- StopJobPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.StopJobPResponse
- StopJobPResponseOrBuilder - Interface in alluxio.grpc
-
- stopLeader() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
Iterates over the masters in the order of master creation, stops the leader master.
- stopLeader() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
Iterates over the masters in the order of master creation, stops the leader master.
- stopMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
-
- stopMasterComponents() - Method in class alluxio.master.AlluxioMasterProcess
-
Stops all masters, including block master, fileSystem master and additional masters.
- stopMasterComponents() - Method in class alluxio.master.AlluxioSimpleMasterProcess
-
- stopMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Stops the masters.
- stopMasters() - Method in class alluxio.master.LocalAlluxioCluster
-
- stopMasters() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
- stopMasters() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
- stopMasters() - Method in class alluxio.multi.process.MultiProcessCluster
-
Stops all masters.
- stopMetricsSystem() - Method in class alluxio.master.service.metrics.MetricsService
-
- STOPPED_VALUE - Static variable in enum alluxio.proto.journal.Job.PJobState
-
STOPPED = 2;
- stopProcessOnShutdown(Process) - Static method in class alluxio.ProcessUtils
-
Adds a shutdown hook that will be invoked when a signal is sent to this process.
- stopProxy() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Stops the proxy.
- stopRejectingServer() - Method in class alluxio.master.service.rpc.RpcServerService
-
- stopRpcExecutor() - Method in class alluxio.master.service.rpc.RpcServerService
-
- stopSinks() - Static method in class alluxio.metrics.MetricsSystem
-
Stops all the sinks.
- stopStandby() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
-
Iterates over the masters in the order of master creation, stops the first standby master.
- stopStandby() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
Iterates over the masters in the order of master creation, stops the first standby master.
- stopUpdate() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
Stop to switch bloom filters and update working set size.
- stopUpdate() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
-
- stopUpdate() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
-
- stopUpdate() - Method in interface alluxio.client.file.cache.ShadowCacheManager
-
Stop the background aging task.
- stopWebServer() - Method in class alluxio.master.service.web.WebServerService
-
- stopWorker(int) - Method in class alluxio.multi.process.MultiProcessCluster
-
- stopWorkers() - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
Stops the workers.
- stopZk() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
-
Stops the cluster's Zookeeper service.
- stopZk() - Method in class alluxio.multi.process.MultiProcessCluster
-
Stops the Zookeeper cluster.
- Storage - Class in alluxio.grpc.table.layout.hive
-
Protobuf type alluxio.grpc.table.layout.Storage
- Storage.Builder - Class in alluxio.grpc.table.layout.hive
-
Protobuf type alluxio.grpc.table.layout.Storage
- STORAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.StorageList
-
- STORAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.PartitionInfo
-
- STORAGE_FORMAT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
-
- StorageCommand - Class in alluxio.cli.fsadmin.doctor
-
Prints server-side storage errors and warnings.
- StorageCommand(BlockMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.doctor.StorageCommand
-
- StorageDir - Interface in alluxio.worker.block.meta
-
Represents a directory in a storage tier.
- StorageFormat - Class in alluxio.grpc.table.layout.hive
-
TODO(binfan): remove this proto file.
- StorageFormat.Builder - Class in alluxio.grpc.table.layout.hive
-
TODO(binfan): remove this proto file.
- StorageFormatOrBuilder - Interface in alluxio.grpc.table.layout.hive
-
- StorageList - Class in alluxio.grpc
-
A list of lost storage paths inside a worker
- StorageList.Builder - Class in alluxio.grpc
-
A list of lost storage paths inside a worker
- StorageListOrBuilder - Interface in alluxio.grpc
-
- StorageOrBuilder - Interface in alluxio.grpc.table.layout.hive
-
- StorageSpaceValidationTask - Class in alluxio.cli
-
Task for validating whether worker tiered storage has enough space.
- StorageSpaceValidationTask(AlluxioConfiguration) - Constructor for class alluxio.cli.StorageSpaceValidationTask
-
- StorageTier - Interface in alluxio.worker.block.meta
-
Represents a tier of storage, for example memory or SSD.
- StorageTierAssoc - Interface in alluxio
-
A two-way mapping between storage tier aliases and ordinal numbers from configuration.
- StorageTierInfo - Class in alluxio.util.webui
-
Class to make referencing tiered storage information more intuitive.
- StorageTierInfo(String, long, long) - Constructor for class alluxio.util.webui.StorageTierInfo
-
Instantiates a new Storage tier info.
- STORAGETIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
-
- stream() - Method in class alluxio.collections.DelegatingSet
-
- stream(T) - Method in class alluxio.grpc.DataMessageMarshaller
-
- STREAM_CACHE_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.ProxyWebServer
-
- StreamCache - Class in alluxio
-
Cache for storing file input and output streams.
- StreamCache(long) - Constructor for class alluxio.StreamCache
-
- streamingRPCAndLog(Logger, RpcUtils.StreamingRpcCallable<T>, String, boolean, boolean, StreamObserver<T>, String, Object...) - Static method in class alluxio.RpcUtils
-
Handles a streaming RPC callable with logging.
- StreamSerializationClientInterceptor - Class in alluxio.client.block.stream
-
Serialization interceptor for client.
- StreamSerializationClientInterceptor() - Constructor for class alluxio.client.block.stream.StreamSerializationClientInterceptor
-
- StreamsRestServiceHandler - Class in alluxio.proxy
-
This class is a REST handler for stream resources.
- StreamsRestServiceHandler(ServletContext) - Constructor for class alluxio.proxy.StreamsRestServiceHandler
-
- streamToJournalCheckpoint(JournalOutputStream) - Method in interface alluxio.master.journalv0.JournalCheckpointStreamable
-
- StreamUtils - Class in alluxio.util
-
Convenience methods for working with streams.
- StressBenchConfig - Class in alluxio.stress.job
-
Config for the stress test.
- StressBenchConfig(String, List<String>, long, int) - Constructor for class alluxio.stress.job.StressBenchConfig
-
- StressBenchDefinition - Class in alluxio.job.plan.stress
-
The definition for the stress bench job, which runs distributed benchmarks.
- StressBenchDefinition() - Constructor for class alluxio.job.plan.stress.StressBenchDefinition
-
Constructs a new instance.
- StressClientIOBench - Class in alluxio.stress.cli.client
-
Client IO stress test.
- StressClientIOBench() - Constructor for class alluxio.stress.cli.client.StressClientIOBench
-
Creates instance.
- StressConstants - Class in alluxio.stress
-
Constants for stress tests.
- StressConstants() - Constructor for class alluxio.stress.StressConstants
-
- StressWorkerBench - Class in alluxio.stress.cli.worker
-
Single node stress test.
- StressWorkerBench() - Constructor for class alluxio.stress.cli.worker.StressWorkerBench
-
Creates instance.
- STRING_ENTRY_FIELD - Static variable in class alluxio.security.authorization.AccessControlList
-
- STRING_STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
-
- STRING_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Value
-
- stringBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
-
- StringColumnStatsData - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.StringColumnStatsData
- StringColumnStatsData.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.StringColumnStatsData
- StringColumnStatsDataOrBuilder - Interface in alluxio.grpc.table
-
- stringToAddress(String) - Static method in class alluxio.cli.fsadmin.journal.QuorumCommand
-
- StringToSignProducer - Class in alluxio.s3.signature
-
Stateless utility to create stringToSign, the base of the signature.
- STRINGVALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.MetricValue
-
- stripInstanceAndHost(String) - Static method in class alluxio.metrics.MetricsSystem
-
Removes the instance and host from the given metric name, returning the result.
- stripLeadingAndTrailingQuotes(String) - Static method in class alluxio.util.CommonUtils
-
Strips the leading and trailing quotes from the given string.
- stripPrefixIfPresent(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Strips the bucket prefix or the preceding path separator from the path if it is present.
- stripPrefixIfPresent(String, String) - Static method in class alluxio.util.CommonUtils
-
Strips the prefix from the key if it is present.
- stripSuffixIfPresent(String, String) - Static method in class alluxio.util.CommonUtils
-
Strips the suffix if it exists.
- StsOssClientProvider - Class in alluxio.underfs.oss
-
STS client provider for Aliyun OSS.
- StsOssClientProvider(UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.oss.StsOssClientProvider
-
- SUBJECT_FIELD_NUMBER - Static variable in class alluxio.grpc.PAclEntry
-
- SUBJECT_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AclEntry
-
- subList(int, int) - Method in class alluxio.collections.UnmodifiableArrayList
-
- SUBMISSIONTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
-
- submit(CmdConfig) - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
-
- submit(CmdConfig) - Method in interface alluxio.client.job.JobMasterClient
-
Submit a Cmd Job based on the given configuration.
- submit(CmdConfig) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- submit(ForkJoinTask<T>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Submits a ForkJoinTask for execution.
- submit(Callable<T>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
- submit(Runnable, T) - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
- submit(Runnable) - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
- submit(SubmitRequest, StreamObserver<SubmitResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
-
Submit a CMD job, return a jobControlId.
- submit(SubmitRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
-
Submit a CMD job, return a jobControlId.
- submit(SubmitRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
-
Submit a CMD job, return a jobControlId.
- submit(SubmitRequest, StreamObserver<SubmitResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
-
Submit a CMD job, return a jobControlId.
- submit(Callable<T>) - Method in class alluxio.master.AlluxioExecutorService
-
- submit(Runnable, T) - Method in class alluxio.master.AlluxioExecutorService
-
- submit(Runnable) - Method in class alluxio.master.AlluxioExecutorService
-
- submit(FileInfo) - Method in class alluxio.master.file.ListStatusPartialResultStream
-
- submit(FileInfo) - Method in class alluxio.master.file.ListStatusResultStream
-
- submit(T) - Method in interface alluxio.master.file.ResultStream
-
Submits a new item to stream.
- submit(CmdConfig) - Method in class alluxio.master.job.JobMaster
-
Submit a job with the given configuration.
- submit(SubmitRequest, StreamObserver<SubmitResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
-
- submit(Runnable) - Method in class alluxio.metrics.InstrumentedExecutorService
-
- submit(Runnable, T) - Method in class alluxio.metrics.InstrumentedExecutorService
-
- submit(Callable<T>) - Method in class alluxio.metrics.InstrumentedExecutorService
-
- submit(Callable<T>) - Method in class alluxio.util.executor.ControllableScheduler
-
- submit(Runnable) - Method in class alluxio.util.executor.ControllableScheduler
-
- submit(Runnable, T) - Method in class alluxio.util.executor.ControllableScheduler
-
- submitCancelTaskCommand(long, long, long) - Method in class alluxio.master.job.command.CommandManager
-
Submits a cancel-task command to a specified worker.
- submitJob(JobRequest) - Method in class alluxio.client.file.DelegatingFileSystem
-
- submitJob(JobRequest) - Method in interface alluxio.client.file.FileSystem
-
Submit a job to scheduler.
- submitJob(JobRequest) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Submit a job to scheduler.
- submitJob(JobRequest) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- submitJob(JobRequest) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
-
- submitJob(SubmitJobPRequest, StreamObserver<SubmitJobPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
-
Load a directory into Alluxio.
- submitJob(SubmitJobPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Load a directory into Alluxio.
- submitJob(SubmitJobPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Load a directory into Alluxio.
- submitJob(SubmitJobPRequest, StreamObserver<SubmitJobPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Load a directory into Alluxio.
- submitJob(SubmitJobPRequest, StreamObserver<SubmitJobPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- submitJob(Job<?>) - Method in class alluxio.master.scheduler.Scheduler
-
Submit a job.
- SubmitJobPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SubmitJobPRequest
- SubmitJobPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SubmitJobPRequest
- SubmitJobPRequestOrBuilder - Interface in alluxio.grpc
-
- SubmitJobPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SubmitJobPResponse
- SubmitJobPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.SubmitJobPResponse
- SubmitJobPResponseOrBuilder - Interface in alluxio.grpc
-
- submitNewRequest(ReqT) - Method in class alluxio.worker.netty.NettyReadHandlerStateMachine
-
Submits a new read request for processing in the state machine.
- SubmitOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.SubmitOptions
- SubmitOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.SubmitOptions
- SubmitOptionsOrBuilder - Interface in alluxio.grpc
-
- SubmitRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.SubmitRequest
- SubmitRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.SubmitRequest
- SubmitRequestOrBuilder - Interface in alluxio.grpc
-
- SubmitResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.SubmitResponse
- SubmitResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.job.SubmitResponse
- SubmitResponseOrBuilder - Interface in alluxio.grpc
-
- submitRunTaskCommand(long, long, JobConfig, Object, long) - Method in class alluxio.master.job.command.CommandManager
-
Submits a run-task command to a specified worker.
- submitSetTaskPoolSizeCommand(long, int) - Method in class alluxio.master.job.command.CommandManager
-
Submits a set thread pool size command to specific worker.
- subProperties(Properties, String) - Static method in class alluxio.metrics.MetricsConfig
-
Uses regex to parse every original property key to a prefix and a suffix.
- subtractPaths(String, String) - Static method in class alluxio.util.io.PathUtils
-
Removes the prefix from the path, yielding a relative path from the second path to the first.
- SUCCEEDED_VALUE - Static variable in enum alluxio.proto.journal.Job.PJobState
-
SUCCEEDED = 3;
- SUCCESS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePResponse
-
- SUCCESS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DetachDatabasePResponse
-
- SUCCESS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.SyncDatabasePResponse
-
- SUCCESS_VALUE - Static variable in enum alluxio.grpc.SaslMessageType
-
SUCCESS = 1;
- SUCCESS_VALUE - Static variable in enum alluxio.grpc.TaskStatus
-
SUCCESS = 0;
- summarizeCollection(Object) - Static method in class alluxio.util.CommonUtils
-
- Summary() - Constructor for class alluxio.job.util.TimeSeries.Summary
-
- Summary - Interface in alluxio.stress
-
The aggregated summary of multiple task results.
- SUMMARY_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobServiceSummaryPResponse
-
- SummaryCommand - Class in alluxio.cli.fsadmin.report
-
Prints Alluxio cluster summarized information.
- SummaryCommand(MetaMasterClient, BlockMasterClient, String, PrintStream) - Constructor for class alluxio.cli.fsadmin.report.SummaryCommand
-
- SummaryOutput - Class in alluxio.cli.fsadmin.report
-
An output class, describing the summary.
- SummaryOutput(MasterInfo, BlockMasterInfo) - Constructor for class alluxio.cli.fsadmin.report.SummaryOutput
-
- SUMMARYPERSTATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobServiceSummary
-
- SummaryStatistics - Class in alluxio.stress.common
-
Statistics class.
- SummaryStatistics() - Constructor for class alluxio.stress.common.SummaryStatistics
-
Creates an instance.
- SummaryStatistics(long, float[], float[], float[]) - Constructor for class alluxio.stress.common.SummaryStatistics
-
Creates an instance.
- supplyAsync(Supplier<U>) - Static method in class alluxio.concurrent.jsr.CompletableFuture
-
Returns a new CompletableFuture that is asynchronously completed by a task running in the
ForkJoinPool.commonPool()
with the value obtained by calling the given Supplier.
- supplyAsync(Supplier<U>, Executor) - Static method in class alluxio.concurrent.jsr.CompletableFuture
-
Returns a new CompletableFuture that is asynchronously completed by a task running in the given
executor with the value obtained by calling the given Supplier.
- SupportedHdfsAclProvider - Class in alluxio.underfs.hdfs.acl
-
Provides the HDFS ACLs.
- SupportedHdfsAclProvider() - Constructor for class alluxio.underfs.hdfs.acl.SupportedHdfsAclProvider
-
- supportsBatchWrite() - Method in interface alluxio.master.metastore.InodeStore
-
- supportsBatchWrite() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
-
- supportsFlush() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- supportsFlush() - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- supportsFlush() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- supportsFlush() - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- supportsFlush() - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- supportsFlush() - Method in interface alluxio.underfs.UnderFileSystem
-
Whether this type of UFS supports flush.
- supportsFlush() - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- supportsPath(String, S) - Method in interface alluxio.extensions.ExtensionFactory
-
Gets whether this factory supports the given path and thus whether calling the
#create(String, S)
can succeed for this path.
- supportsPath(String) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.adl.AdlUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystemFactory
-
- supportsPath(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.cos.COSUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.cosn.CosNUnderFileSystemFactory
-
- supportsPath(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cosn.CosNUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
-
- supportsPath(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.local.LocalUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.ozone.OzoneUnderFileSystemFactory
-
- supportsPath(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.ozone.OzoneUnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystemFactory
-
- supportsPath(String) - Method in interface alluxio.underfs.UnderFileSystemFactory
-
- supportsPath(String, UnderFileSystemConfiguration) - Method in interface alluxio.underfs.UnderFileSystemFactory
-
- supportsPath(String) - Method in class alluxio.underfs.wasb.WasbUnderFileSystemFactory
-
- supportsVersion(Version) - Method in class alluxio.master.backcompat.ops.SetAcl
-
- supportsVersion(Version) - Method in interface alluxio.master.backcompat.TestOp
-
- SuppressFBWarnings - Annotation Type in alluxio.annotation
-
Suppresses warnings by findbugs-maven-plugin.
- suspend(Runnable) - Method in interface alluxio.master.journal.JournalSystem
-
Suspends applying for all journals.
- suspend(Runnable) - Method in class alluxio.master.journal.noop.NoopJournalSystem
-
- suspend() - Method in class alluxio.master.journal.raft.BufferedJournalApplier
-
Suspend the applier.
- suspend(Runnable) - Method in class alluxio.master.journal.raft.JournalStateMachine
-
Suspends applying to masters.
- suspend(Runnable) - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- suspend() - Method in class alluxio.master.journal.ufs.UfsJournal
-
Suspends applying this journal until resumed.
- suspend(Runnable) - Method in class alluxio.master.journal.ufs.UfsJournalSystem
-
- SWIFT_AUTH_KEYSTONE - Static variable in class alluxio.Constants
-
- SWIFT_AUTH_KEYSTONE_V3 - Static variable in class alluxio.Constants
-
- SWIFT_AUTH_SWIFTAUTH - Static variable in class alluxio.Constants
-
- symlink(String, String) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- symlink(String, String) - Method in interface alluxio.jnifuse.FuseFileSystem
-
- symlinkCallback(String, String) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- sync() - Method in class alluxio.master.file.InodeSyncStream
-
Sync the metadata according the root path the stream was created with.
- SYNC_STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePResponse
-
- SyncCheck - Class in alluxio.master.file.meta
-
- SyncCheck.SyncResult - Class in alluxio.master.file.meta
-
- syncDatabase(String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- syncDatabase(String) - Method in interface alluxio.client.table.TableMasterClient
-
Syncs an existing database in the catalog master.
- syncDatabase(SyncDatabasePRequest, StreamObserver<SyncDatabasePResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
-
Sync existing database into the catalog
- syncDatabase(SyncDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
-
Sync existing database into the catalog
- syncDatabase(SyncDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
-
Sync existing database into the catalog
- syncDatabase(SyncDatabasePRequest, StreamObserver<SyncDatabasePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
-
Sync existing database into the catalog
- SyncDatabasePRequest - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.SyncDatabasePRequest
- SyncDatabasePRequest.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.SyncDatabasePRequest
- SyncDatabasePRequestOrBuilder - Interface in alluxio.grpc.table
-
- SyncDatabasePResponse - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.SyncDatabasePResponse
- SyncDatabasePResponse.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.SyncDatabasePResponse
- SyncDatabasePResponseOrBuilder - Interface in alluxio.grpc.table
-
- Syncing_VALUE - Static variable in enum alluxio.grpc.SyncPointStatus
-
Syncing = 1;
- SYNCINTERVALMS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemMasterCommonPOptions
-
- SYNCPARENTNEXTTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePOptions
-
- syncPersistExistingDirectory(Supplier<JournalContext>, InodeDirectoryView, boolean) - Method in class alluxio.master.file.meta.InodeTree
-
Synchronously persists an inode directory to the UFS.
- syncPersistNewDirectory(MutableInodeDirectory, CreatePathContext<?, ?>) - Method in class alluxio.master.file.meta.InodeTree
-
Synchronously persists an inode directory to the UFS.
- SYNCPOINT_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddSyncPointEntry
-
- SYNCPOINT_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RemoveSyncPointEntry
-
- SyncPointStatus - Enum in alluxio.grpc
-
Protobuf enum alluxio.grpc.file.SyncPointStatus
- SyncStatus - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.SyncStatus
- SyncStatus.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.SyncStatus
- SyncStatusOrBuilder - Interface in alluxio.grpc.table
-
- syncSuccess() - Method in class alluxio.master.file.meta.SyncCheck
-
This method should be called if the sync was performed successfully.
- SYSTEM - Static variable in class alluxio.time.TimeContext
-
- SYSTEM_PROPERTY - Static variable in class alluxio.conf.Source
-
- SYSTEM_VALUE - Static variable in enum alluxio.grpc.JobSource
-
SYSTEM = 3;
- SystemClock - Class in alluxio.clock
-
A clock representing the current time as reported by the operating system.
- SystemClock() - Constructor for class alluxio.clock.SystemClock
-
Constructs a new Clock
which reports the actual time.
- SystemUserGroupAuthPolicy - Class in alluxio.fuse.auth
-
The system user group authentication policy that always set the user group
to the actual end user.