- CacheableIPList - Class in org.apache.hadoop.util
- 
CacheableIPList loads a list of subnets from a file. 
- CacheableIPList(FileBasedIPList, long) - Constructor for class org.apache.hadoop.util.CacheableIPList
-  
- CachedDNSToSwitchMapping - Class in org.apache.hadoop.net
- 
A cached implementation of DNSToSwitchMapping that takes an
 raw DNSToSwitchMapping and stores the resolved network location in 
 a cache. 
- CachedDNSToSwitchMapping(DNSToSwitchMapping) - Constructor for class org.apache.hadoop.net.CachedDNSToSwitchMapping
- 
cache a raw DNS mapping 
- cacheGroupsAdd(List<String>) - Method in interface org.apache.hadoop.security.GroupMappingServiceProvider
- 
Caches the group user information 
- cacheGroupsAdd(List<String>) - Method in class org.apache.hadoop.security.JniBasedUnixGroupsMappingWithFallback
-  
- cacheGroupsAdd(List<String>) - Method in class org.apache.hadoop.security.JniBasedUnixGroupsNetgroupMappingWithFallback
-  
- cacheGroupsAdd(List<String>) - Method in class org.apache.hadoop.security.NullGroupsMapping
- 
Nothing is returned, so nothing is cached. 
- cacheGroupsRefresh() - Method in interface org.apache.hadoop.security.GroupMappingServiceProvider
- 
Refresh the cache of groups and user mapping 
- cacheGroupsRefresh() - Method in class org.apache.hadoop.security.JniBasedUnixGroupsMappingWithFallback
-  
- cacheGroupsRefresh() - Method in class org.apache.hadoop.security.JniBasedUnixGroupsNetgroupMappingWithFallback
-  
- cacheGroupsRefresh() - Method in class org.apache.hadoop.security.NullGroupsMapping
- 
Nothing is returned, so nothing is cached. 
- CachingKeyProvider - Class in org.apache.hadoop.crypto.key
- 
A KeyProviderExtensionimplementation providing a short lived
 cache forKeyVersionsandMetadatato avoid burst
 of requests to hit the underlyingKeyProvider.
 
- CachingKeyProvider(KeyProvider, long, long) - Constructor for class org.apache.hadoop.crypto.key.CachingKeyProvider
-  
- call(RPC.RpcKind, Writable, Client.ConnectionId, AtomicBoolean) - Method in class org.apache.hadoop.ipc.Client
- 
Make a call, passing rpcRequest, to the IPC server defined byremoteId, returning the rpc respond.
 
- call(RPC.RpcKind, Writable, Client.ConnectionId, AtomicBoolean, AlignmentContext) - Method in class org.apache.hadoop.ipc.Client
-  
- call(RPC.RpcKind, String, Writable, long) - Method in class org.apache.hadoop.ipc.RPC.Server
-  
- call(Writable, long) - Method in class org.apache.hadoop.ipc.Server
- 
- call(RPC.RpcKind, String, Writable, long) - Method in class org.apache.hadoop.ipc.Server
- 
Called for each call. 
- CallerContext.Builder - Class in org.apache.hadoop.ipc
- 
The caller context builder. 
- CallerContext.Builder(String) - Constructor for class org.apache.hadoop.ipc.CallerContext.Builder
-  
- CALLERCONTEXT_FIELD_NUMBER - Static variable in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
-  
- CALLID_FIELD_NUMBER - Static variable in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
-  
- CALLID_FIELD_NUMBER - Static variable in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
-  
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService
-  
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService
-  
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshProtocolService
-  
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueProtocolService
-  
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService
-  
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshAuthorizationPolicyProtocolService
-  
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserMappingsProtocolService
-  
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService
-  
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.tracing.TraceAdminPB.TraceAdminService
-  
- CallQueueManager<E extends org.apache.hadoop.ipc.Schedulable> - Class in org.apache.hadoop.ipc
- 
Abstracts queue operations for different blocking queues. 
- CallQueueManager(Class<? extends BlockingQueue<E>>, Class<? extends RpcScheduler>, boolean, int, String, Configuration) - Constructor for class org.apache.hadoop.ipc.CallQueueManager
-  
- CAN_UNBUFFER_NOT_IMPLEMENTED_MESSAGE - Static variable in class org.apache.hadoop.fs.StreamCapabilitiesPolicy
-  
- cancel(Token<?>, Configuration) - Method in class org.apache.hadoop.crypto.key.kms.KMSClientProvider.KMSTokenRenewer
-  
- cancel() - Method in interface org.apache.hadoop.io.ReadaheadPool.ReadaheadRequest
- 
Cancels the request for readahead. 
- cancel(Configuration) - Method in class org.apache.hadoop.security.token.Token
- 
Cancel this delegation token 
- cancel(Token<?>, Configuration) - Method in class org.apache.hadoop.security.token.Token.TrivialRenewer
-  
- cancel(Token<?>, Configuration) - Method in class org.apache.hadoop.security.token.TokenRenewer
- 
Cancel the given token 
- cancelDelegationToken(Token<?>) - Method in interface org.apache.hadoop.crypto.key.KeyProviderDelegationTokenExtension.DelegationTokenExtension
- 
Cancels the given token. 
- cancelDelegationToken(Token<?>) - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- cancelDelegationToken(URL, DelegationTokenAuthenticatedURL.Token) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
- 
Cancels a delegation token from the server end-point. 
- cancelDelegationToken(URL, DelegationTokenAuthenticatedURL.Token, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
- 
Cancels a delegation token from the server end-point. 
- cancelDelegationToken(URL, AuthenticatedURL.Token, Token<AbstractDelegationTokenIdentifier>) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
- 
Cancels a delegation token from the server end-point. 
- cancelDelegationToken(URL, AuthenticatedURL.Token, Token<AbstractDelegationTokenIdentifier>, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
- 
Cancels a delegation token from the server end-point. 
- cancelDeleteOnExit(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Cancel the scheduled deletion of the path when the FileSystem is closed. 
- cancelToken(Token<TokenIdent>, String) - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
- 
Cancel a token by removing it from cache. 
- canExecute(File) - Static method in class org.apache.hadoop.fs.FileUtil
- 
- CANNOT_SEEK_PAST_EOF - Static variable in class org.apache.hadoop.fs.FSExceptionMessages
- 
Seeks : "Attempted to seek or read past the end of the file" 
- canonicalizeUri(URI) - Method in class org.apache.hadoop.fs.FileSystem
- 
Canonicalize the given URI. 
- canonicalizeUri(URI) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- canonicalizeUri(URI) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- canRead(File) - Static method in class org.apache.hadoop.fs.FileUtil
- 
- CanSetDropBehind - Interface in org.apache.hadoop.fs
-  
- CanSetReadahead - Interface in org.apache.hadoop.fs
-  
- CanUnbuffer - Interface in org.apache.hadoop.fs
- 
FSDataInputStreams implement this interface to indicate that they can clear
 their buffers on request. 
- canWrite(File) - Static method in class org.apache.hadoop.fs.FileUtil
- 
- CAT_CONFIG - Static variable in class org.apache.hadoop.security.KDiag
-  
- CAT_JAAS - Static variable in class org.apache.hadoop.security.KDiag
-  
- CAT_JVM - Static variable in class org.apache.hadoop.security.KDiag
-  
- CAT_KERBEROS - Static variable in class org.apache.hadoop.security.KDiag
-  
- CAT_LOGIN - Static variable in class org.apache.hadoop.security.KDiag
-  
- CAT_OS - Static variable in class org.apache.hadoop.security.KDiag
-  
- CAT_SASL - Static variable in class org.apache.hadoop.security.KDiag
-  
- CAT_TOKEN - Static variable in class org.apache.hadoop.security.KDiag
-  
- CAT_UGI - Static variable in class org.apache.hadoop.security.KDiag
-  
- CBZip2InputStream - Class in org.apache.hadoop.io.compress.bzip2
- 
An input stream that decompresses from the BZip2 format (without the file
 header chars) to be read as any other stream. 
- CBZip2InputStream(InputStream, SplittableCompressionCodec.READ_MODE) - Constructor for class org.apache.hadoop.io.compress.bzip2.CBZip2InputStream
- 
Constructs a new CBZip2InputStream which decompresses bytes read from the
 specified stream. 
- CBZip2InputStream(InputStream) - Constructor for class org.apache.hadoop.io.compress.bzip2.CBZip2InputStream
-  
- CBZip2InputStream.STATE - Enum in org.apache.hadoop.io.compress.bzip2
- 
A state machine to keep track of current state of the de-coder 
- CBZip2OutputStream - Class in org.apache.hadoop.io.compress.bzip2
- 
An output stream that compresses into the BZip2 format (without the file
 header chars) into another stream. 
- CBZip2OutputStream(OutputStream) - Constructor for class org.apache.hadoop.io.compress.bzip2.CBZip2OutputStream
- 
Constructs a new CBZip2OutputStream with a blocksize of 900k. 
- CBZip2OutputStream(OutputStream, int) - Constructor for class org.apache.hadoop.io.compress.bzip2.CBZip2OutputStream
- 
Constructs a new CBZip2OutputStream with specified blocksize. 
- cedeActive(RpcController, ZKFCProtocolProtos.CedeActiveRequestProto) - Method in interface org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService.BlockingInterface
-  
- cedeActive(RpcController, ZKFCProtocolProtos.CedeActiveRequestProto, RpcCallback<ZKFCProtocolProtos.CedeActiveResponseProto>) - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService
- 
rpc cedeActive(.hadoop.common.CedeActiveRequestProto) returns (.hadoop.common.CedeActiveResponseProto);
 
- cedeActive(RpcController, ZKFCProtocolProtos.CedeActiveRequestProto, RpcCallback<ZKFCProtocolProtos.CedeActiveResponseProto>) - Method in interface org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService.Interface
- 
rpc cedeActive(.hadoop.common.CedeActiveRequestProto) returns (.hadoop.common.CedeActiveResponseProto);
 
- cedeActive(RpcController, ZKFCProtocolProtos.CedeActiveRequestProto, RpcCallback<ZKFCProtocolProtos.CedeActiveResponseProto>) - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService.Stub
-  
- cedeActive(int) - Method in class org.apache.hadoop.ha.protocolPB.ZKFCProtocolClientSideTranslatorPB
-  
- CHALLENGE_FIELD_NUMBER - Static variable in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
-  
- CHALLENGE_VALUE - Static variable in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslState
- 
CHALLENGE = 3;
 
- changed() - Method in class org.apache.hadoop.metrics2.lib.MutableMetric
-  
- charAt(int) - Method in class org.apache.hadoop.io.Text
- 
Returns the Unicode Scalar Value (32-bit integer value)
 for the character at position.
 
- check(String) - Method in class org.apache.hadoop.fs.DUHelper
-  
- check(String, SSLSocket) - Method in class org.apache.hadoop.security.ssl.SSLHostnameVerifier.AbstractVerifier
-  
- check(String, X509Certificate) - Method in class org.apache.hadoop.security.ssl.SSLHostnameVerifier.AbstractVerifier
-  
- check(String, String[], String[]) - Method in class org.apache.hadoop.security.ssl.SSLHostnameVerifier.AbstractVerifier
-  
- check(String[], SSLSocket) - Method in class org.apache.hadoop.security.ssl.SSLHostnameVerifier.AbstractVerifier
-  
- check(String[], X509Certificate) - Method in class org.apache.hadoop.security.ssl.SSLHostnameVerifier.AbstractVerifier
-  
- check(String[], String[], String[], boolean, boolean) - Method in class org.apache.hadoop.security.ssl.SSLHostnameVerifier.AbstractVerifier
-  
- checkArgs(String) - Method in interface org.apache.hadoop.ha.FenceMethod
- 
Verify that the given fencing method's arguments are valid. 
- checkArgs(String) - Method in class org.apache.hadoop.ha.PowerShellFencer
-  
- checkArgs(String) - Method in class org.apache.hadoop.ha.ShellCommandFencer
-  
- checkArgs(String) - Method in class org.apache.hadoop.ha.SshFenceByTcpPort
- 
Verify that the argument, if given, in the conf is parseable. 
- checkAvailableForRead() - Method in class org.apache.hadoop.security.token.SecretManager
- 
No-op if the secret manager is available for reading tokens, throw a
 StandbyException otherwise. 
- checkFencingConfigured() - Method in class org.apache.hadoop.ha.HAServiceTarget
-  
- checkIsBashSupported() - Static method in class org.apache.hadoop.util.Shell
-  
- checkNativeCodeLoaded() - Static method in class org.apache.hadoop.io.compress.SnappyCodec
- 
Are the native snappy libraries loaded & initialized? 
- checkNativeCodeLoaded() - Static method in class org.apache.hadoop.io.compress.ZStandardCodec
-  
- checkPath(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Check that a Path belongs to this FileSystem. 
- checkPath(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Check that a Path belongs to this FileSystem. 
- checkPath(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
Check that a Path belongs to this FileSystem. 
- checkPath(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- checkpoint() - Method in class org.apache.hadoop.fs.Trash
- 
Create a trash checkpoint. 
- checkScheme(URI, String) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Check that the Uri's scheme matches 
- checkStateTransition(String, Service.STATE, Service.STATE) - Static method in class org.apache.hadoop.service.ServiceStateModel
- 
Check that a state tansition is valid and
 throw an exception if not 
- checkStatus(File) - Method in class org.apache.hadoop.util.BasicDiskValidator
-  
- checkStatus(File) - Method in class org.apache.hadoop.util.ReadWriteDiskValidator
-  
- checkStream() - Method in class org.apache.hadoop.io.compress.DecompressorStream
-  
- ChecksumException - Exception in org.apache.hadoop.fs
- 
Thrown for checksum errors. 
- ChecksumException(String, long) - Constructor for exception org.apache.hadoop.fs.ChecksumException
-  
- ChecksumFileSystem - Class in org.apache.hadoop.fs
- 
Abstract Checksumed FileSystem. 
- ChecksumFileSystem(FileSystem) - Constructor for class org.apache.hadoop.fs.ChecksumFileSystem
-  
- checksumOpt(Options.ChecksumOpt) - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
- 
Set checksum opt. 
- checksumParam(Options.ChecksumOpt) - Static method in class org.apache.hadoop.fs.Options.CreateOpts
-  
- checkTGTAndReloginFromKeytab() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Re-login a user from keytab if TGT is expired or is close to expiry. 
- checkToken(TokenIdent) - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
- 
Find the DelegationTokenInformation for the given token id, and verify that
 if the token is expired. 
- checkWindowsCommandLineLength(String...) - Static method in class org.apache.hadoop.util.Shell
- 
Checks if a given command (String[]) fits in the Windows maximum command
 line length Note that the input is expected to already include space
 delimiters, no extra count will be added for delimiters. 
- children - Variable in class org.apache.hadoop.net.InnerNodeImpl
-  
- childrenMap - Variable in class org.apache.hadoop.net.InnerNodeImpl
-  
- chmod(String, String) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Change the permissions on a filename. 
- chmod(String, String, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Change the permissions on a file / directory, recursively, if
 needed. 
- chmod(String, int) - Static method in class org.apache.hadoop.io.nativeio.NativeIO.POSIX
-  
- chooseBlockSize(long) - Static method in class org.apache.hadoop.io.compress.bzip2.CBZip2OutputStream
- 
Chooses a blocksize based on the given length of the data to compress. 
- CLASSNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
-  
- CLASSNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
-  
- cleanup(Log, Closeable...) - Static method in class org.apache.hadoop.io.IOUtils
- 
- cleanup() - Method in class org.apache.hadoop.io.SequenceFile.Sorter.SegmentDescriptor
- 
The default cleanup. 
- cleanupWithLogger(Logger, Closeable...) - Static method in class org.apache.hadoop.io.IOUtils
- 
Close the Closeable objects and  ignore any  Throwable or
 null pointers. 
- clear() - Method in class org.apache.hadoop.conf.Configuration
- 
Clears all keys from the configuration. 
- clear() - Method in class org.apache.hadoop.fs.HardLink.LinkStats
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.io.MapWritable
-  
- clear() - Method in class org.apache.hadoop.io.SortedMapWritable
-  
- clear() - Method in class org.apache.hadoop.io.Text
- 
Clear the string to empty. 
- clear() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
-  
- clear() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
-  
- clear() - Method in interface org.apache.hadoop.metrics2.util.QuantileEstimator
-  
- clear() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
-  
- clear() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
-  
- clear() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto.Builder
-  
- clear() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto.Builder
-  
- clear() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
-  
- clear() - Method in class org.apache.hadoop.util.bloom.HashFunction
- 
Clears this hash function. 
- CLEAR_TEXT_FALLBACK - Static variable in class org.apache.hadoop.security.alias.CredentialProvider
-  
- clearArgs() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
- 
repeated string args = 2;
 
- clearAuths() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- clearCallerContext() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- clearCallId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
required sint32 callId = 3;
 
- clearCallId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
required uint32 callId = 1;
 
- clearChallenge() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional bytes challenge = 5;
 
- clearChanged() - Method in class org.apache.hadoop.metrics2.lib.MutableMetric
- 
Clear the changed flag in the snapshot operations 
- clearClassName() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
required string className = 1;
 
- clearClassName() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
- 
required string className = 2;
 
- clearClientCache() - Static method in class org.apache.hadoop.ipc.ProtobufRpcEngine
-  
- clearClientId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
required bytes clientId = 4;
 
- clearClientId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional bytes clientId = 7;
 
- clearClientProtocolVersion() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required uint64 clientProtocolVersion = 3;
 
- clearConfig() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- clearContext() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
- 
required string context = 1;
 
- clearDeclaringClassProtocolName() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required string declaringClassProtocolName = 2;
 
- clearDescriptions() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- clearEffectiveUser() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
- 
optional string effectiveUser = 1;
 
- clearErrorDetail() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional .hadoop.common.RpcResponseHeaderProto.RpcErrorCodeProto errorDetail = 6;
 
- clearErrorMsg() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional string errorMsg = 5;
 
- clearExceptionClassName() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional string exceptionClassName = 4;
 
- clearExitStatus() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional int32 exitStatus = 1;
 
- clearGroups() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder
- 
repeated string groups = 1;
 
- clearId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto.Builder
- 
required int64 id = 1;
 
- clearId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto.Builder
- 
required int64 id = 1;
 
- clearId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
- 
required int64 id = 1;
 
- clearIdentifier() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
- 
optional string identifier = 1;
 
- clearIdentifier() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required bytes identifier = 1;
 
- clearKey() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
- 
required string key = 1;
 
- clearKind() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required string kind = 3;
 
- CLEARMASK - Static variable in class org.apache.hadoop.io.compress.bzip2.CBZip2OutputStream
- 
This constant is accessible by subclasses for historical purposes. 
- clearMechanism() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
required string mechanism = 2;
 
- clearMethod() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
required string method = 1;
 
- clearMethodName() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required string methodName = 1;
 
- clearMethods() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
- 
repeated uint32 methods = 2;
 
- clearMillisToCede() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto.Builder
- 
required uint32 millisToCede = 1;
 
- clearNameMaps() - Method in class org.apache.hadoop.security.ShellBasedIdMapping
-  
- clearNewExpiryTime() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto.Builder
- 
required uint64 newExpiryTime = 1;
 
- clearNotReadyReason() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
- 
optional string notReadyReason = 3;
 
- clearParentId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
- 
optional int64 parentId = 2;
 
- clearPassword() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required bytes password = 2;
 
- clearProtocol() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
- 
optional string protocol = 3;
 
- clearProtocol() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
- 
required string protocol = 1;
 
- clearProtocol() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto.Builder
- 
required string protocol = 1;
 
- clearProtocol() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional string protocol = 3;
 
- clearProtocolSignature() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- clearProtocolVersions() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- clearReadyToBecomeActive() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
- 
optional bool readyToBecomeActive = 2;
 
- clearRealUser() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
- 
optional string realUser = 2;
 
- clearRenewer() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto.Builder
- 
required string renewer = 1;
 
- clearReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- clearReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- clearReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- clearReqSource() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto.Builder
- 
required .hadoop.common.HARequestSource reqSource = 1;
 
- clearResponses() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- clearRetryCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional sint32 retryCount = 5 [default = -1];
 
- clearRetryCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional sint32 retryCount = 8 [default = -1];
 
- clearRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
- 
required string rpcKind = 2;
 
- clearRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
- 
required string rpcKind = 1;
 
- clearRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RpcKindProto rpcKind = 1;
 
- clearRpcOp() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2;
 
- clearSenderName() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional string senderName = 3;
 
- clearServerId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional string serverId = 4;
 
- clearServerIpcVersionNum() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional uint32 serverIpcVersionNum = 3;
 
- clearService() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required string service = 4;
 
- clearShutdownHooks() - Method in class org.apache.hadoop.util.ShutdownHookManager
- 
clear all registered shutdownHooks. 
- clearSignature() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
- 
optional bytes signature = 2;
 
- clearState() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
- 
required .hadoop.common.HAServiceStateProto state = 1;
 
- clearState() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
required .hadoop.common.RpcSaslProto.SaslState state = 2;
 
- clearStateId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional int64 stateId = 8;
 
- clearStateId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional int64 stateId = 9;
 
- clearStatistics() - Static method in class org.apache.hadoop.fs.AbstractFileSystem
-  
- clearStatistics() - Static method in class org.apache.hadoop.fs.FileContext
- 
Clears all the statistics stored in AbstractFileSystem, for all the file
 systems. 
- clearStatistics() - Static method in class org.apache.hadoop.fs.FileSystem
- 
Reset all statistics for all file systems. 
- clearStatus() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
required .hadoop.common.RpcResponseHeaderProto.RpcStatusProto status = 2;
 
- clearToken() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
optional bytes token = 3;
 
- clearToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto.Builder
- 
required .hadoop.common.TokenProto token = 1;
 
- clearToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto.Builder
- 
optional .hadoop.common.TokenProto token = 1;
 
- clearToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto.Builder
- 
required .hadoop.common.TokenProto token = 1;
 
- clearTraceId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
- 
optional int64 traceId = 1;
 
- clearTraceInfo() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- clearUser() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto.Builder
- 
required string user = 1;
 
- clearUserInfo() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- clearUserMessage() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional string userMessage = 2;
 
- clearValue() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
- 
required string value = 2;
 
- clearVersion() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
- 
required uint64 version = 1;
 
- clearVersion() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
optional uint32 version = 1;
 
- clearVersions() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
- 
repeated uint64 versions = 2;
 
- Client - Class in org.apache.hadoop.ipc
- 
A client for an IPC service. 
- Client(Class<? extends Writable>, Configuration, SocketFactory) - Constructor for class org.apache.hadoop.ipc.Client
- 
Construct an IPC client whose values are of the given  Writable
 class. 
- Client(Class<? extends Writable>, Configuration) - Constructor for class org.apache.hadoop.ipc.Client
- 
Construct an IPC client with the default SocketFactory 
- CLIENTID_FIELD_NUMBER - Static variable in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
-  
- CLIENTID_FIELD_NUMBER - Static variable in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
-  
- CLIENTPROTOCOLVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto.Builder
-  
- clone(T, Configuration) - Static method in class org.apache.hadoop.io.WritableUtils
- 
Make a copy of a writable object using serialization to a buffer. 
- clone() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
-  
- clone() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
-  
- clone() - Method in class org.apache.hadoop.record.Buffer
- 
Deprecated. 
- clone() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
-  
- clone() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
-  
- clone() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto.Builder
-  
- clone() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto.Builder
-  
- clone() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
-  
- clone() - Method in class org.apache.hadoop.util.GcTimeMonitor.GcData
-  
- cloneFileAttributes(Path, Path, Progressable) - Method in class org.apache.hadoop.io.SequenceFile.Sorter
- 
Clones the attributes (like compression of the input file and creates a 
 corresponding Writer 
- cloneInto(Writable, Writable) - Static method in class org.apache.hadoop.io.WritableUtils
- 
Deprecated.
use ReflectionUtils.cloneInto instead. 
 
- cloneWritableInto(Writable, Writable) - Static method in class org.apache.hadoop.util.ReflectionUtils
- 
Deprecated. 
- close() - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Can be used by implementing classes to close any resources
 that require closing 
- close() - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- close() - Method in class org.apache.hadoop.fs.AvroFSInput
-  
- close() - Method in class org.apache.hadoop.fs.FileSystem
- 
Close this FileSystem instance. 
- close() - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- close() - Method in class org.apache.hadoop.fs.FSDataOutputStream
- 
Close the underlying output stream. 
- close() - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- close() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- close() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- close() - Method in class org.apache.hadoop.ha.protocolPB.ZKFCProtocolClientSideTranslatorPB
-  
- close() - Method in class org.apache.hadoop.http.HttpRequestLogAppender
-  
- close() - Method in class org.apache.hadoop.io.BloomMapFile.Writer
-  
- close() - Method in class org.apache.hadoop.io.compress.bzip2.CBZip2InputStream
-  
- close() - Method in class org.apache.hadoop.io.compress.bzip2.CBZip2OutputStream
-  
- close() - Method in class org.apache.hadoop.io.compress.CompressionInputStream
-  
- close() - Method in class org.apache.hadoop.io.compress.CompressionOutputStream
-  
- close() - Method in class org.apache.hadoop.io.compress.CompressorStream
-  
- close() - Method in class org.apache.hadoop.io.compress.DecompressorStream
-  
- close() - Method in class org.apache.hadoop.io.compress.GzipCodec.GzipOutputStream
-  
- close() - Method in class org.apache.hadoop.io.DefaultStringifier
-  
- close() - Method in class org.apache.hadoop.io.file.tfile.BoundedRangeFileInputStream
-  
- close() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Close the reader. 
- close() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner
- 
Close the scanner. 
- close() - Method in class org.apache.hadoop.io.file.tfile.TFile.Writer
- 
Close the Writer. 
- close() - Method in class org.apache.hadoop.io.MapFile.Reader
- 
Close the map. 
- close() - Method in class org.apache.hadoop.io.MapFile.Writer
- 
Close the map. 
- close() - Method in class org.apache.hadoop.io.retry.DefaultFailoverProxyProvider
-  
- close() - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Close the file. 
- close() - Method in interface org.apache.hadoop.io.SequenceFile.Sorter.RawKeyValueIterator
- 
closes the iterator so that the underlying streams can be closed 
- close() - Method in class org.apache.hadoop.io.SequenceFile.Writer
- 
Close the file. 
- close() - Method in interface org.apache.hadoop.io.Stringifier
- 
Closes this object. 
- close() - Method in class org.apache.hadoop.ipc.Client
-  
- close() - Method in class org.apache.hadoop.ipc.ProtobufRpcEngine.Invoker
-  
- close() - Method in class org.apache.hadoop.ipc.protocolPB.GenericRefreshProtocolClientSideTranslatorPB
-  
- close() - Method in class org.apache.hadoop.ipc.protocolPB.RefreshCallQueueProtocolClientSideTranslatorPB
-  
- close() - Method in class org.apache.hadoop.log.metrics.EventCounter
-  
- close() - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
- 
Deprecated. method to close the datagram socket 
- close() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- 
Deprecated. Stops monitoring and frees buffered data, returning this
 object to its initial state. 
- close() - Method in class org.apache.hadoop.metrics2.lib.MutableRollingAverages
-  
- close() - Method in class org.apache.hadoop.metrics2.sink.FileSink
-  
- close() - Method in class org.apache.hadoop.metrics2.sink.GraphiteSink
-  
- close() - Method in class org.apache.hadoop.metrics2.sink.GraphiteSink.Graphite
-  
- close() - Method in class org.apache.hadoop.metrics2.sink.RollingFileSystemSink
-  
- close() - Method in class org.apache.hadoop.metrics2.sink.StatsDSink
-  
- close() - Method in class org.apache.hadoop.metrics2.sink.StatsDSink.StatsD
-  
- close() - Method in class org.apache.hadoop.security.KDiag
-  
- close() - Method in class org.apache.hadoop.security.protocolPB.RefreshAuthorizationPolicyProtocolClientSideTranslatorPB
-  
- close() - Method in class org.apache.hadoop.security.protocolPB.RefreshUserMappingsProtocolClientSideTranslatorPB
-  
- close() - Method in class org.apache.hadoop.service.AbstractService
- 
- close() - Method in interface org.apache.hadoop.service.Service
- 
A version of stop() that is designed to be usable in Java7 closure
 clauses. 
- close() - Method in class org.apache.hadoop.tools.protocolPB.GetUserMappingsProtocolClientSideTranslatorPB
-  
- close() - Method in class org.apache.hadoop.util.AutoCloseableLock
- 
Attempts to release the lock by making a call to release().
 
- close() - Method in interface org.apache.hadoop.util.Shell.CommandExecutor
-  
- close() - Method in class org.apache.hadoop.util.Shell.ShellCommandExecutor
-  
- close() - Method in class org.apache.hadoop.util.StopWatch
-  
- Closeable - Interface in org.apache.hadoop.io
- 
Deprecated.
use java.io.Closeable 
 
- CloseableReferenceCount - Class in org.apache.hadoop.util
- 
A closeable object that maintains a reference count. 
- CloseableReferenceCount() - Constructor for class org.apache.hadoop.util.CloseableReferenceCount
-  
- closeAll() - Static method in class org.apache.hadoop.fs.FileSystem
- 
Close all cached FileSystem instances. 
- closeAllForUGI(UserGroupInformation) - Static method in class org.apache.hadoop.fs.FileSystem
- 
Close all cached FileSystem instances for a given UGI. 
- closed - Variable in class org.apache.hadoop.io.compress.CompressorStream
-  
- closed - Variable in class org.apache.hadoop.io.compress.DecompressorStream
-  
- closeSocket(Socket) - Static method in class org.apache.hadoop.io.IOUtils
- 
- closeStream(Closeable) - Static method in class org.apache.hadoop.io.IOUtils
- 
- closeStreams(Closeable...) - Static method in class org.apache.hadoop.io.IOUtils
- 
- code - Variable in enum org.apache.hadoop.security.SaslRpcServer.AuthMethod
- 
The code for this method. 
- CodeBuffer - Class in org.apache.hadoop.record.compiler
- 
- CodecPool - Class in org.apache.hadoop.io.compress
- 
A global compressor/decompressor pool used to save and reuse 
 (possibly native) compression/decompression codecs. 
- CodecPool() - Constructor for class org.apache.hadoop.io.compress.CodecPool
-  
- collectThreadLocalStates() - Method in class org.apache.hadoop.metrics2.lib.MutableRollingAverages
- 
- column - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
- 
Deprecated. 
- combine(Result) - Method in class org.apache.hadoop.fs.shell.find.Result
- 
Returns the combination of this and another result. 
- combine(Class<T>, Object...) - Static method in class org.apache.hadoop.ipc.ProxyCombiner
- 
Combine two or more proxies which together comprise a single proxy
 interface. 
- CombinedIPWhiteList - Class in org.apache.hadoop.util
-  
- CombinedIPWhiteList(String, String, long) - Constructor for class org.apache.hadoop.util.CombinedIPWhiteList
-  
- COMMA_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
- 
Deprecated. 
- CommandFormat - Class in org.apache.hadoop.fs.shell
- 
Parse the args of a command and check the format of args. 
- CommandFormat(String, int, int, String...) - Constructor for class org.apache.hadoop.fs.shell.CommandFormat
- 
Deprecated.
use replacement since name is an unused parameter 
 
- CommandFormat(int, int, String...) - Constructor for class org.apache.hadoop.fs.shell.CommandFormat
- 
Simple parsing of command line arguments 
- CommandFormat.DuplicatedOptionException - Exception in org.apache.hadoop.fs.shell
- 
Used when a duplicated option is supplied to a command. 
- CommandFormat.DuplicatedOptionException(String) - Constructor for exception org.apache.hadoop.fs.shell.CommandFormat.DuplicatedOptionException
-  
- CommandFormat.IllegalNumberOfArgumentsException - Exception in org.apache.hadoop.fs.shell
- 
Used when the arguments exceed their bounds 
- CommandFormat.IllegalNumberOfArgumentsException(int, int) - Constructor for exception org.apache.hadoop.fs.shell.CommandFormat.IllegalNumberOfArgumentsException
-  
- CommandFormat.NotEnoughArgumentsException - Exception in org.apache.hadoop.fs.shell
- 
Used when too few arguments are supplied to a command 
- CommandFormat.NotEnoughArgumentsException(int, int) - Constructor for exception org.apache.hadoop.fs.shell.CommandFormat.NotEnoughArgumentsException
-  
- CommandFormat.TooManyArgumentsException - Exception in org.apache.hadoop.fs.shell
- 
Used when too many arguments are supplied to a command 
- CommandFormat.TooManyArgumentsException(int, int) - Constructor for exception org.apache.hadoop.fs.shell.CommandFormat.TooManyArgumentsException
-  
- CommandFormat.UnknownOptionException - Exception in org.apache.hadoop.fs.shell
- 
Used when an unsupported option is supplied to a command 
- CommandFormat.UnknownOptionException(String) - Constructor for exception org.apache.hadoop.fs.shell.CommandFormat.UnknownOptionException
-  
- commit() - Method in class org.apache.hadoop.util.curator.ZKCuratorManager.SafeTransaction
-  
- CommonConfigurationKeysPublic - Class in org.apache.hadoop.fs
- 
This class contains constants for configuration keys used
 in the common code. 
- CommonConfigurationKeysPublic() - Constructor for class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- ComparableVersion - Class in org.apache.hadoop.util
- 
Generic implementation of version comparison. 
- ComparableVersion(String) - Constructor for class org.apache.hadoop.util.ComparableVersion
-  
- comparator(WritableComparator) - Static method in class org.apache.hadoop.io.MapFile.Reader
-  
- comparator(WritableComparator) - Static method in class org.apache.hadoop.io.MapFile.Writer
-  
- comparator() - Method in class org.apache.hadoop.io.SortedMapWritable
-  
- COMPARATOR_JCLASS - Static variable in class org.apache.hadoop.io.file.tfile.TFile
- 
comparator prefix: java class 
- COMPARATOR_MEMCMP - Static variable in class org.apache.hadoop.io.file.tfile.TFile
- 
comparator: memcmp 
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.BooleanWritable.Comparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.BytesWritable.Comparator
- 
Compare the buffers in serialized form. 
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.ByteWritable.Comparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.DoubleWritable.Comparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.FloatWritable.Comparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.IntWritable.Comparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.LongWritable.Comparator
-  
- compare(WritableComparable, WritableComparable) - Method in class org.apache.hadoop.io.LongWritable.DecreasingComparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.LongWritable.DecreasingComparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.MD5Hash.Comparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.NullWritable.Comparator
- 
Compare the buffers in serialized form. 
- compare(byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.io.RawComparator
- 
Compare two objects in binary. 
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.ShortWritable.Comparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.Text.Comparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.UTF8.Comparator
- 
Deprecated. 
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.WritableComparator
- 
Optimization hook. 
- compare(WritableComparable, WritableComparable) - Method in class org.apache.hadoop.io.WritableComparator
- 
Compare two WritableComparables. 
- compare(Object, Object) - Method in class org.apache.hadoop.io.WritableComparator
-  
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.record.RecordComparator
- 
Deprecated. 
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.io.WritableComparator
- 
Lexicographic order of binary data. 
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.record.Utils
- 
Deprecated. Lexicographic order of binary data. 
- compareFs(FileSystem, FileSystem) - Static method in class org.apache.hadoop.fs.FileUtil
-  
- compareTo(Delayed) - Method in class org.apache.hadoop.fs.DelegationTokenRenewer.RenewAction
-  
- compareTo(FileStatus) - Method in class org.apache.hadoop.fs.FileStatus
- 
Compare this FileStatus to another FileStatus 
- compareTo(FileStatus) - Method in class org.apache.hadoop.fs.LocatedFileStatus
- 
Compare this FileStatus to another FileStatus 
- compareTo(Object) - Method in class org.apache.hadoop.fs.Path
-  
- compareTo(BinaryComparable) - Method in class org.apache.hadoop.io.BinaryComparable
- 
Compare bytes from {#getBytes()}. 
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.io.BinaryComparable
- 
Compare bytes from {#getBytes()} to those provided. 
- compareTo(BooleanWritable) - Method in class org.apache.hadoop.io.BooleanWritable
-  
- compareTo(ByteWritable) - Method in class org.apache.hadoop.io.ByteWritable
- 
Compares two ByteWritables. 
- compareTo(DoubleWritable) - Method in class org.apache.hadoop.io.DoubleWritable
-  
- compareTo(byte[]) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Compare the entry key to another key. 
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Compare the entry key to another key. 
- compareTo(RawComparable) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Compare an entry with a RawComparable object. 
- compareTo(Utils.Version) - Method in class org.apache.hadoop.io.file.tfile.Utils.Version
- 
Compare this version with another version. 
- compareTo(FloatWritable) - Method in class org.apache.hadoop.io.FloatWritable
- 
Compares two FloatWritables. 
- compareTo(IntWritable) - Method in class org.apache.hadoop.io.IntWritable
- 
Compares two IntWritables. 
- compareTo(LongWritable) - Method in class org.apache.hadoop.io.LongWritable
- 
Compares two LongWritables. 
- compareTo(MD5Hash) - Method in class org.apache.hadoop.io.MD5Hash
- 
Compares this object with the specified object for order. 
- compareTo(NullWritable) - Method in class org.apache.hadoop.io.NullWritable
-  
- compareTo(Object) - Method in class org.apache.hadoop.io.SequenceFile.Sorter.SegmentDescriptor
-  
- compareTo(ShortWritable) - Method in class org.apache.hadoop.io.ShortWritable
- 
Compares two ShortWritable. 
- compareTo(VIntWritable) - Method in class org.apache.hadoop.io.VIntWritable
- 
Compares two VIntWritables. 
- compareTo(VLongWritable) - Method in class org.apache.hadoop.io.VLongWritable
- 
Compares two VLongWritables. 
- compareTo(Object) - Method in class org.apache.hadoop.record.Buffer
- 
Deprecated. Define the sort order of the Buffer. 
- compareTo(Object) - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
- 
Deprecated. This class doesn't implement Comparable as it's not meant to be used 
 for anything besides de/serializing. 
- compareTo(Object) - Method in class org.apache.hadoop.record.Record
- 
Deprecated. 
- compareTo(ComparableVersion) - Method in class org.apache.hadoop.util.ComparableVersion
-  
- compatibleWith(Utils.Version) - Method in class org.apache.hadoop.io.file.tfile.Utils.Version
- 
Test compatibility. 
- compile(String) - Method in class org.apache.hadoop.metrics2.filter.GlobFilter
-  
- compile(String) - Method in class org.apache.hadoop.metrics2.filter.RegexFilter
-  
- completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
-  
- completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Called when we're all done writing to the target. 
- completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
Called when we're all done writing to the target. 
- completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.HarFileSystem
- 
not implemented. 
- completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- CompositeContext - Class in org.apache.hadoop.metrics.spi
- 
Deprecated.
Use org.apache.hadoop.metrics2 package instead. 
 
- CompositeContext() - Constructor for class org.apache.hadoop.metrics.spi.CompositeContext
- 
Deprecated. 
- CompositeService - Class in org.apache.hadoop.service
- 
Composition of services. 
- CompositeService(String) - Constructor for class org.apache.hadoop.service.CompositeService
-  
- CompositeService.CompositeServiceShutdownHook - Class in org.apache.hadoop.service
- 
JVM Shutdown hook for CompositeService which will stop the give
 CompositeService gracefully in case of JVM shutdown. 
- CompositeService.CompositeServiceShutdownHook(CompositeService) - Constructor for class org.apache.hadoop.service.CompositeService.CompositeServiceShutdownHook
-  
- compress() - Method in class org.apache.hadoop.io.compress.BlockCompressorStream
-  
- compress(byte[], int, int) - Method in class org.apache.hadoop.io.compress.bzip2.Bzip2Compressor
-  
- compress(byte[], int, int) - Method in class org.apache.hadoop.io.compress.bzip2.BZip2DummyCompressor
-  
- compress(byte[], int, int) - Method in interface org.apache.hadoop.io.compress.Compressor
- 
Fills specified buffer with compressed data. 
- compress() - Method in class org.apache.hadoop.io.compress.CompressorStream
-  
- compress(byte[], int, int) - Method in class org.apache.hadoop.io.compress.lz4.Lz4Compressor
- 
Fills specified buffer with compressed data. 
- compress(byte[], int, int) - Method in class org.apache.hadoop.io.compress.snappy.SnappyCompressor
- 
Fills specified buffer with compressed data. 
- compress(byte[], int, int) - Method in class org.apache.hadoop.io.compress.zlib.BuiltInZlibDeflater
-  
- compress(byte[], int, int) - Method in class org.apache.hadoop.io.compress.zlib.ZlibCompressor
-  
- compress(byte[], int, int) - Method in class org.apache.hadoop.io.compress.zstd.ZStandardCompressor
-  
- compressedValSerializer - Variable in class org.apache.hadoop.io.SequenceFile.Writer
-  
- CompressedWritable - Class in org.apache.hadoop.io
- 
A base-class for Writables which store themselves compressed and lazily
 inflate on field access. 
- CompressedWritable() - Constructor for class org.apache.hadoop.io.CompressedWritable
-  
- Compression - Class in org.apache.hadoop.io.file.tfile
- 
Compression related stuff. 
- compression(SequenceFile.CompressionType) - Static method in class org.apache.hadoop.io.MapFile.Writer
-  
- compression(SequenceFile.CompressionType, CompressionCodec) - Static method in class org.apache.hadoop.io.MapFile.Writer
-  
- compression(SequenceFile.CompressionType) - Static method in class org.apache.hadoop.io.SequenceFile.Writer
-  
- compression(SequenceFile.CompressionType, CompressionCodec) - Static method in class org.apache.hadoop.io.SequenceFile.Writer
-  
- Compression.Algorithm - Enum in org.apache.hadoop.io.file.tfile
- 
Compression algorithms. 
- COMPRESSION_GZ - Static variable in class org.apache.hadoop.io.file.tfile.TFile
- 
compression: gzip 
- COMPRESSION_LZO - Static variable in class org.apache.hadoop.io.file.tfile.TFile
- 
compression: lzo 
- COMPRESSION_NONE - Static variable in class org.apache.hadoop.io.file.tfile.TFile
- 
compression: none 
- CompressionCodec - Interface in org.apache.hadoop.io.compress
- 
This class encapsulates a streaming compression/decompression pair. 
- CompressionCodec.Util - Class in org.apache.hadoop.io.compress
-  
- CompressionCodec.Util() - Constructor for class org.apache.hadoop.io.compress.CompressionCodec.Util
-  
- CompressionCodecFactory - Class in org.apache.hadoop.io.compress
- 
A factory that will find the correct codec for a given filename. 
- CompressionCodecFactory(Configuration) - Constructor for class org.apache.hadoop.io.compress.CompressionCodecFactory
- 
Find the codecs specified in the config value io.compression.codecs 
 and register them. 
- CompressionInputStream - Class in org.apache.hadoop.io.compress
- 
A compression input stream. 
- CompressionInputStream(InputStream) - Constructor for class org.apache.hadoop.io.compress.CompressionInputStream
- 
Create a compression input stream that reads
 the decompressed bytes from the given stream. 
- CompressionOutputStream - Class in org.apache.hadoop.io.compress
- 
A compression output stream. 
- CompressionOutputStream(OutputStream) - Constructor for class org.apache.hadoop.io.compress.CompressionOutputStream
- 
Create a compression output stream that writes
 the compressed bytes to the given stream. 
- Compressor - Interface in org.apache.hadoop.io.compress
- 
- compressor - Variable in class org.apache.hadoop.io.compress.CompressorStream
-  
- CompressorStream - Class in org.apache.hadoop.io.compress
-  
- CompressorStream(OutputStream, Compressor, int) - Constructor for class org.apache.hadoop.io.compress.CompressorStream
-  
- CompressorStream(OutputStream, Compressor) - Constructor for class org.apache.hadoop.io.compress.CompressorStream
-  
- CompressorStream(OutputStream) - Constructor for class org.apache.hadoop.io.compress.CompressorStream
- 
Allow derived classes to directly set the underlying stream. 
- concat(Path, Path[]) - Method in class org.apache.hadoop.fs.FileSystem
- 
Concat existing files together. 
- concat(Path, Path[]) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- conf - Static variable in enum org.apache.hadoop.io.file.tfile.Compression.Algorithm
-  
- CONF_HADOOP_PROXYSERVERS - Static variable in class org.apache.hadoop.security.authorize.ProxyServers
-  
- CONF_LZO_CLASS - Static variable in enum org.apache.hadoop.io.file.tfile.Compression.Algorithm
-  
- CONF_SERVLET_RECONFIGURABLE_PREFIX - Static variable in class org.apache.hadoop.conf.ReconfigurationServlet
-  
- CONFIG_FIELD_NUMBER - Static variable in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
-  
- CONFIG_VIEWFS_DEFAULT_MOUNT_TABLE - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Config variable name for the default mount table. 
- CONFIG_VIEWFS_ENABLE_INNER_CACHE - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Enable ViewFileSystem to cache all children filesystems in inner cache. 
- CONFIG_VIEWFS_ENABLE_INNER_CACHE_DEFAULT - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
-  
- CONFIG_VIEWFS_HOMEDIR - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Prefix for the home dir for the mount table - if not specified
 then the hadoop default value (/user) is used. 
- CONFIG_VIEWFS_LINK - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Config variable for specifying a simple link 
- CONFIG_VIEWFS_LINK_FALLBACK - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Config variable for specifying a fallback for link mount points. 
- CONFIG_VIEWFS_LINK_MERGE - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Config variable for specifying a merge link 
- CONFIG_VIEWFS_LINK_MERGE_SLASH - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Config variable for specifying a merge of the root of the mount-table
  with the root of another file system. 
- CONFIG_VIEWFS_LINK_NFLY - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Config variable for specifying an nfly link. 
- CONFIG_VIEWFS_PREFIX - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Prefix for the config variable prefix for the ViewFs mount-table 
- CONFIG_VIEWFS_PREFIX_DEFAULT_MOUNT_TABLE - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Config variable full prefix for the default mount table. 
- CONFIG_VIEWFS_RENAME_STRATEGY - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
-  
- CONFIG_VIEWFS_TRASH_FORCE_INSIDE_MOUNT_POINT - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
- 
Force ViewFileSystem to return a trashRoot that is inside a mount point. 
- CONFIG_VIEWFS_TRASH_FORCE_INSIDE_MOUNT_POINT_DEFAULT - Static variable in interface org.apache.hadoop.fs.viewfs.Constants
-  
- ConfigRedactor - Class in org.apache.hadoop.conf
- 
Tool for redacting sensitive information when displaying config parameters. 
- ConfigRedactor(Configuration) - Constructor for class org.apache.hadoop.conf.ConfigRedactor
-  
- Configurable - Interface in org.apache.hadoop.conf
- 
- Configuration - Class in org.apache.hadoop.conf
- 
Provides access to configuration parameters. 
- Configuration() - Constructor for class org.apache.hadoop.conf.Configuration
- 
A new configuration. 
- Configuration(boolean) - Constructor for class org.apache.hadoop.conf.Configuration
- 
A new configuration where the behavior of reading from the default 
 resources can be turned off. 
- Configuration(Configuration) - Constructor for class org.apache.hadoop.conf.Configuration
- 
A new configuration with the same settings cloned from another. 
- Configuration.DeprecationDelta - Class in org.apache.hadoop.conf
- 
A pending addition to the global set of deprecated keys. 
- Configuration.DeprecationDelta(String, String, String) - Constructor for class org.apache.hadoop.conf.Configuration.DeprecationDelta
-  
- Configuration.DeprecationDelta(String, String) - Constructor for class org.apache.hadoop.conf.Configuration.DeprecationDelta
-  
- Configuration.IntegerRanges - Class in org.apache.hadoop.conf
- 
A class that represents a set of positive integer ranges. 
- Configuration.IntegerRanges() - Constructor for class org.apache.hadoop.conf.Configuration.IntegerRanges
-  
- Configuration.IntegerRanges(String) - Constructor for class org.apache.hadoop.conf.Configuration.IntegerRanges
-  
- Configured - Class in org.apache.hadoop.conf
- 
Base class for things that may be configured with a  Configuration. 
- Configured() - Constructor for class org.apache.hadoop.conf.Configured
- 
Construct a Configured. 
- Configured(Configuration) - Constructor for class org.apache.hadoop.conf.Configured
- 
Construct a Configured. 
- configureXFrame(boolean) - Method in class org.apache.hadoop.http.HttpServer2.Builder
- 
Adds the ability to control X_FRAME_OPTIONS on HttpServer2. 
- ConfigUtil - Class in org.apache.hadoop.fs.viewfs
- 
Utilities for config variables of the viewFs See  ViewFs
- ConfigUtil() - Constructor for class org.apache.hadoop.fs.viewfs.ConfigUtil
-  
- confirmPrompt(String) - Static method in class org.apache.hadoop.util.ToolRunner
- 
Print out a prompt to the user, and return true if the user
 responds with "y" or "yes". 
- ConfServlet.BadFormatException - Exception in org.apache.hadoop.conf
-  
- ConfServlet.BadFormatException(String) - Constructor for exception org.apache.hadoop.conf.ConfServlet.BadFormatException
-  
- connect() - Method in class org.apache.hadoop.metrics2.sink.GraphiteSink.Graphite
-  
- ConnectTimeoutException - Exception in org.apache.hadoop.net
- 
Thrown by NetUtils.connect(java.net.Socket, java.net.SocketAddress, int)if it times out while connecting to the remote host.
 
- ConnectTimeoutException(String) - Constructor for exception org.apache.hadoop.net.ConnectTimeoutException
-  
- Constants - Interface in org.apache.hadoop.fs.viewfs
- 
Config variable prefixes for ViewFs -
     see  ViewFs for examples. 
- construct(ZlibCompressor.CompressionLevel, ZlibCompressor.CompressionStrategy, ZlibCompressor.CompressionHeader, int) - Method in class org.apache.hadoop.io.compress.zlib.ZlibCompressor
-  
- constructOutputStream(DataOutput) - Static method in class org.apache.hadoop.io.DataOutputOutputStream
- 
Construct an OutputStream from the given DataOutput. 
- constructRpcRequest(Method, Message) - Method in class org.apache.hadoop.ipc.ProtobufRpcEngine.Invoker
-  
- Consts - Class in org.apache.hadoop.record.compiler
- 
- containsHeader(String) - Method in class org.apache.hadoop.security.http.XFrameOptionsFilter.XFrameOptionsResponseWrapper
-  
- containsKey(Object) - Method in class org.apache.hadoop.io.MapWritable
-  
- containsKey(Object) - Method in class org.apache.hadoop.io.SortedMapWritable
-  
- containsValue(Object) - Method in class org.apache.hadoop.io.MapWritable
-  
- containsValue(Object) - Method in class org.apache.hadoop.io.SortedMapWritable
-  
- ContentSummary - Class in org.apache.hadoop.fs
- 
Store the summary of a content (a directory or a file). 
- ContentSummary() - Constructor for class org.apache.hadoop.fs.ContentSummary
- 
Deprecated. 
- ContentSummary(long, long, long) - Constructor for class org.apache.hadoop.fs.ContentSummary
- 
Deprecated. 
- ContentSummary(long, long, long, long, long, long) - Constructor for class org.apache.hadoop.fs.ContentSummary
- 
Deprecated. 
- ContentSummary.Builder - Class in org.apache.hadoop.fs
- 
We don't use generics. 
- ContentSummary.Builder() - Constructor for class org.apache.hadoop.fs.ContentSummary.Builder
-  
- context() - Method in interface org.apache.hadoop.metrics2.MetricsRecord
-  
- CONTEXT_FIELD_NUMBER - Static variable in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
-  
- convert(Throwable) - Static method in exception org.apache.hadoop.service.ServiceStateException
- 
- convert(String, Throwable) - Static method in exception org.apache.hadoop.service.ServiceStateException
- 
- convert(RpcHeaderProtos.RpcKindProto) - Static method in class org.apache.hadoop.util.ProtoUtil
-  
- convertToExitException(Throwable) - Static method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Convert an exception to an ExitException.
 
- copy(Path, Path) - Method in class org.apache.hadoop.fs.FileContext.Util
- 
Copy file from src to dest. 
- copy(Path, Path, boolean, boolean) - Method in class org.apache.hadoop.fs.FileContext.Util
- 
Copy from src to dst, optionally deleting src and overwriting dst. 
- copy(FileSystem, Path, FileSystem, Path, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Copy files between FileSystems. 
- copy(FileSystem, Path[], FileSystem, Path, boolean, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
-  
- copy(FileSystem, Path, FileSystem, Path, boolean, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Copy files between FileSystems. 
- copy(FileSystem, FileStatus, FileSystem, Path, boolean, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Copy files between FileSystems. 
- copy(File, FileSystem, Path, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Copy local files to a FileSystem. 
- copy(FileSystem, Path, File, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Copy FileSystem files to local files. 
- copy(Writable) - Method in class org.apache.hadoop.io.AbstractMapWritable
- 
Used by child copy constructors. 
- copy(byte[], int, int) - Method in class org.apache.hadoop.record.Buffer
- 
Deprecated. Copy the specified byte array to the Buffer. 
- copy(Configuration, T, T) - Static method in class org.apache.hadoop.util.ReflectionUtils
- 
Make a copy of the writable object using serialization to a buffer 
- copyBytes() - Method in class org.apache.hadoop.io.BytesWritable
- 
Get a copy of the bytes that is exactly the length of the data. 
- copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.hadoop.io.IOUtils
- 
Copies from one stream to another. 
- copyBytes(InputStream, OutputStream, int) - Static method in class org.apache.hadoop.io.IOUtils
- 
Copies from one stream to another. 
- copyBytes(InputStream, OutputStream, Configuration) - Static method in class org.apache.hadoop.io.IOUtils
- 
Copies from one stream to another. 
- copyBytes(InputStream, OutputStream, Configuration, boolean) - Static method in class org.apache.hadoop.io.IOUtils
- 
Copies from one stream to another. 
- copyBytes(InputStream, OutputStream, long, boolean) - Static method in class org.apache.hadoop.io.IOUtils
- 
Copies count bytes from one stream to another. 
- copyBytes() - Method in class org.apache.hadoop.io.Text
- 
Get a copy of the bytes that is exactly the length of the data. 
- copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
-  
- copyFromLocalFile(Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
The src file is on the local disk. 
- copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
The src file is on the local disk. 
- copyFromLocalFile(boolean, boolean, Path[], Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
The src files are on the local disk. 
- copyFromLocalFile(boolean, boolean, Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
The src file is on the local disk. 
- copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
The src file is on the local disk. 
- copyFromLocalFile(boolean, boolean, Path[], Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
The src files are on the local disk. 
- copyFromLocalFile(boolean, boolean, Path, Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
The src file is on the local disk. 
- copyFromLocalFile(boolean, boolean, Path, Path) - Method in class org.apache.hadoop.fs.HarFileSystem
- 
not implemented. 
- copyFromLocalFile(boolean, boolean, Path[], Path) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.LocalFileSystem
-  
- copyMerge(FileSystem, Path, FileSystem, Path, boolean, Configuration, String) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Deprecated. 
- copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
- 
The src file is under FS, and the dst is on the local disk. 
- copyToLocalFile(Path, Path, boolean) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
- 
The src file is under FS, and the dst is on the local disk. 
- copyToLocalFile(Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Copy it a file from the remote filesystem to the local one. 
- copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Copy it a file from a remote filesystem to the local one. 
- copyToLocalFile(boolean, Path, Path, boolean) - Method in class org.apache.hadoop.fs.FileSystem
- 
The src file is under this filesystem, and the dst is on the local disk. 
- copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
The src file is under FS, and the dst is on the local disk. 
- copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.HarFileSystem
- 
copies the file in the har filesystem to a local file. 
- copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.LocalFileSystem
-  
- coreServiceLaunch(Configuration, List<String>, boolean, boolean) - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Launch the service. 
- CostProvider - Interface in org.apache.hadoop.ipc
- 
- count - Variable in class org.apache.hadoop.io.file.tfile.SimpleBufferedOutputStream
-  
- countDirs - Variable in class org.apache.hadoop.fs.HardLink.LinkStats
-  
- countDots(String) - Static method in class org.apache.hadoop.security.ssl.SSLHostnameVerifier.AbstractVerifier
- 
Counts the number of dots "." in a string. 
- countEmptyDirs - Variable in class org.apache.hadoop.fs.HardLink.LinkStats
-  
- counter(MetricsInfo, int) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
- 
Callback for integer value counters 
- counter(MetricsInfo, long) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
- 
Callback for long value counters 
- countFilesMultLinks - Variable in class org.apache.hadoop.fs.HardLink.LinkStats
-  
- CountingBloomFilter - Class in org.apache.hadoop.util.bloom
- 
Implements a counting Bloom filter, as defined by Fan et al. 
- CountingBloomFilter() - Constructor for class org.apache.hadoop.util.bloom.CountingBloomFilter
- 
Default constructor - use with readFields 
- CountingBloomFilter(int, int, int) - Constructor for class org.apache.hadoop.util.bloom.CountingBloomFilter
- 
Constructor 
- countMultLinks - Variable in class org.apache.hadoop.fs.HardLink.LinkStats
-  
- countPhysicalFileCopies - Variable in class org.apache.hadoop.fs.HardLink.LinkStats
-  
- countSingleLinks - Variable in class org.apache.hadoop.fs.HardLink.LinkStats
-  
- create(Path, EnumSet<CreateFlag>, Options.CreateOpts...) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
-  
- create(Path, EnumSet<CreateFlag>, Options.CreateOpts...) - Method in class org.apache.hadoop.fs.FileContext
- 
Create or overwrite file on indicated path and returns an output stream for
 writing into the file. 
- create(FileSystem, Path, FsPermission) - Static method in class org.apache.hadoop.fs.FileSystem
- 
Create a file with the provided permission. 
- create(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path. 
- create(Path, boolean) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path. 
- create(Path, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path with write-progress
 reporting. 
- create(Path, short) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path. 
- create(Path, short, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path with write-progress
 reporting. 
- create(Path, boolean, int) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path. 
- create(Path, boolean, int, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
- 
- create(Path, boolean, int, short, long) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path. 
- create(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path with write-progress
 reporting. 
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path with write-progress
 reporting. 
- create(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path with write-progress
 reporting. 
- create(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable, Options.ChecksumOpt) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create an FSDataOutputStream at the indicated Path with a custom
 checksum option. 
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- create(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable, Options.ChecksumOpt) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- create() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
- 
Create an FSDataOutputStream at the specified path. 
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
- 
A stream obtained via this call must be closed before using other APIs of
 this class or else the invocation will block. 
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- create(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.sftp.SFTPFileSystem
- 
A stream obtained via this call must be closed before using other APIs of
 this class or else the invocation will block. 
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- create(Class<T>, T, RetryPolicy) - Static method in class org.apache.hadoop.io.retry.RetryProxy
- 
 Create a proxy for an interface of an implementation class
 using the same retry policy for each method in the interface. 
- create(Class<T>, FailoverProxyProvider<T>, RetryPolicy) - Static method in class org.apache.hadoop.io.retry.RetryProxy
- 
Create a proxy for an interface of implementations of that interface using
 the given  FailoverProxyProvider and the same retry policy for each
 method in the interface. 
- create(Class<T>, T, Map<String, RetryPolicy>) - Static method in class org.apache.hadoop.io.retry.RetryProxy
- 
Create a proxy for an interface of an implementation class
 using the a set of retry policies specified by method name. 
- create(Class<T>, FailoverProxyProvider<T>, Map<String, RetryPolicy>, RetryPolicy) - Static method in class org.apache.hadoop.io.retry.RetryProxy
- 
Create a proxy for an interface of implementations of that interface using
 the given  FailoverProxyProvider and the a set of retry policies
 specified by method name. 
- create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.util.curator.ZKCuratorManager.SafeTransaction
-  
- CREATE_ALWAYS - Static variable in class org.apache.hadoop.io.nativeio.NativeIO.Windows
-  
- CREATE_NEW - Static variable in class org.apache.hadoop.io.nativeio.NativeIO.Windows
-  
- createCheckpoint() - Method in class org.apache.hadoop.fs.TrashPolicy
- 
Create a trash checkpoint. 
- createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.hadoop.io.file.tfile.Compression.Algorithm
-  
- createCompressor() - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
- createCompressor() - Method in interface org.apache.hadoop.io.compress.CompressionCodec
- 
- createCompressor() - Method in class org.apache.hadoop.io.compress.DefaultCodec
-  
- createCompressor() - Method in class org.apache.hadoop.io.compress.GzipCodec
-  
- createCompressor() - Method in class org.apache.hadoop.io.compress.Lz4Codec
- 
- createCompressor() - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
- createCompressor() - Method in class org.apache.hadoop.io.compress.ZStandardCodec
- 
- createConfiguration() - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Override point: create the base configuration for the service. 
- createCredentialEntry(String, char[]) - Method in class org.apache.hadoop.security.alias.CredentialProvider
- 
Create a new credential. 
- createDataFileReader(Path, Configuration, SequenceFile.Reader.Option...) - Method in class org.apache.hadoop.io.MapFile.Reader
- 
- createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.io.file.tfile.Compression.Algorithm
-  
- createDecompressor() - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
- createDecompressor() - Method in interface org.apache.hadoop.io.compress.CompressionCodec
- 
- createDecompressor() - Method in class org.apache.hadoop.io.compress.DefaultCodec
-  
- createDecompressor() - Method in class org.apache.hadoop.io.compress.GzipCodec
-  
- createDecompressor() - Method in class org.apache.hadoop.io.compress.Lz4Codec
- 
- createDecompressor() - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
- createDecompressor() - Method in class org.apache.hadoop.io.compress.ZStandardCodec
- 
- createDirectDecompressor() - Method in class org.apache.hadoop.io.compress.DefaultCodec
- 
- createDirectDecompressor() - Method in interface org.apache.hadoop.io.compress.DirectDecompressionCodec
- 
- createDirectDecompressor() - Method in class org.apache.hadoop.io.compress.GzipCodec
-  
- createDirectDecompressor() - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
- createDirectDecompressor() - Method in class org.apache.hadoop.io.compress.ZStandardCodec
-  
- createDirectoryWithMode(File, int) - Static method in class org.apache.hadoop.io.nativeio.NativeIO.Windows
- 
Create a directory with permissions set to the specified mode. 
- createDisabled() - Static method in class org.apache.hadoop.fs.Options.ChecksumOpt
- 
Create a ChecksumOpts that disables checksum 
- createFile(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create a new FSDataOutputStreamBuilder for the file with path. 
- createFile(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- createFile(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- createFile(String, long, long, long) - Static method in class org.apache.hadoop.io.nativeio.NativeIO.Windows
- 
Wrapper around CreateFile() on Windows 
- createFileOutputStreamWithMode(File, boolean, int) - Static method in class org.apache.hadoop.io.nativeio.NativeIO.Windows
- 
Create a file for write with permissions set to the specified mode. 
- createFileSystem(URI, Configuration) - Static method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Create a file system instance for the specified uri using the conf. 
- CreateFlag - Enum in org.apache.hadoop.fs
- 
CreateFlag specifies the file create semantic. 
- createForDecryption(String, String, byte[], byte[]) - Static method in class org.apache.hadoop.crypto.key.KeyProviderCryptoExtension.EncryptedKeyVersion
- 
Factory method to create a new EncryptedKeyVersion that can then be
 passed into KeyProviderCryptoExtension.decryptEncryptedKey(org.apache.hadoop.crypto.key.KeyProviderCryptoExtension.EncryptedKeyVersion).
 
- createForWrite(File, int) - Static method in class org.apache.hadoop.io.SecureIOUtils
- 
Open the specified File for write access, ensuring that it does not exist. 
- createGenericOptionsParser(Configuration, String[]) - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Override point: create a generic options parser or subclass thereof. 
- createHardLink(File, File) - Static method in class org.apache.hadoop.fs.HardLink
- 
Creates a hardlink 
- createHardLinkMult(File, String[], File) - Static method in class org.apache.hadoop.fs.HardLink
- 
Creates hardlinks from multiple existing files within one parent
 directory, into one target directory. 
- createIdentifier() - Method in class org.apache.hadoop.security.token.SecretManager
- 
Create an empty token identifier. 
- createImmutable(short) - Static method in class org.apache.hadoop.fs.permission.FsPermission
- 
- createInputStream(InputStream) - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
Create a  CompressionInputStream that will read from the given
 input stream and return a stream for uncompressed data. 
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
- createInputStream(InputStream, Decompressor, long, long, SplittableCompressionCodec.READ_MODE) - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
Creates CompressionInputStream to be used to read off uncompressed data
 in one of the two reading modes. 
- createInputStream(InputStream) - Method in interface org.apache.hadoop.io.compress.CompressionCodec
- 
- createInputStream(InputStream, Decompressor) - Method in interface org.apache.hadoop.io.compress.CompressionCodec
- 
- createInputStream(InputStream) - Method in class org.apache.hadoop.io.compress.DefaultCodec
-  
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.io.compress.DefaultCodec
-  
- createInputStream(InputStream) - Method in class org.apache.hadoop.io.compress.GzipCodec
-  
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.io.compress.GzipCodec
-  
- createInputStream(InputStream) - Method in class org.apache.hadoop.io.compress.Lz4Codec
- 
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.io.compress.Lz4Codec
- 
- createInputStream(InputStream) - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
- createInputStream(InputStream, Decompressor, long, long, SplittableCompressionCodec.READ_MODE) - Method in interface org.apache.hadoop.io.compress.SplittableCompressionCodec
- 
Create a stream as dictated by the readMode. 
- createInputStream(InputStream) - Method in class org.apache.hadoop.io.compress.ZStandardCodec
- 
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.io.compress.ZStandardCodec
- 
- createInternal(Path, EnumSet<CreateFlag>, FsPermission, int, short, long, Progressable, Options.ChecksumOpt, boolean) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
- createInternal(Path, EnumSet<CreateFlag>, FsPermission, int, short, long, Progressable, Options.ChecksumOpt, boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- createIOException(List<IOException>) - Static method in exception org.apache.hadoop.io.MultipleIOException
- 
- createJarWithClassPath(String, Path, Map<String, String>) - Static method in class org.apache.hadoop.fs.FileUtil
-  
- createJarWithClassPath(String, Path, Path, Map<String, String>) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Create a jar file at the given path, containing a manifest with a classpath
 that references all specified entries. 
- createKey(String, byte[], KeyProvider.Options) - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Create a new key. 
- createKey(String, KeyProvider.Options) - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Create a new key generating the material for it. 
- createKey(String, KeyProvider.Options) - Method in class org.apache.hadoop.crypto.key.KeyProviderExtension
-  
- createKey(String, byte[], KeyProvider.Options) - Method in class org.apache.hadoop.crypto.key.KeyProviderExtension
-  
- createKey(String, byte[], KeyProvider.Options) - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- createKey(String, KeyProvider.Options) - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- createKeyProviderDelegationTokenExtension(KeyProvider) - Static method in class org.apache.hadoop.crypto.key.KeyProviderDelegationTokenExtension
- 
Creates a  KeyProviderDelegationTokenExtension using a given
  KeyProvider. 
- createLocalTempFile(File, String, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Create a tmp file for a base file. 
- createNewFile(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Creates the given Path as a brand-new zero-length file. 
- createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
-  
- createNonRecursive(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
- 
Opens an FSDataOutputStream at the indicated Path with write-progress
 reporting. 
- createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
- 
Opens an FSDataOutputStream at the indicated Path with write-progress
 reporting. 
- createNonRecursive(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
- 
Opens an FSDataOutputStream at the indicated Path with write-progress
 reporting. 
- createNonRecursive(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- createNonRecursive(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- createNonRecursive(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- createNonRecursive(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- createOptions() - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Override point: create an options instance to combine with the 
 standard options set. 
- createOutputStream(Path, boolean) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
- createOutputStream(OutputStream) - Method in interface org.apache.hadoop.io.compress.CompressionCodec
- 
- createOutputStream(OutputStream, Compressor) - Method in interface org.apache.hadoop.io.compress.CompressionCodec
- 
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.io.compress.DefaultCodec
-  
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.io.compress.DefaultCodec
-  
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.io.compress.GzipCodec
-  
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.io.compress.GzipCodec
-  
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.io.compress.Lz4Codec
- 
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.io.compress.Lz4Codec
- 
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.io.compress.ZStandardCodec
- 
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.io.compress.ZStandardCodec
- 
- createOutputStreamWithMode(Path, boolean, FsPermission) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- createParent() - Static method in class org.apache.hadoop.fs.Options.CreateOpts
-  
- createPassword(TokenIdent) - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
-  
- createPassword(T) - Method in class org.apache.hadoop.security.token.SecretManager
- 
Create the password for the given identifier. 
- createPassword(byte[], SecretKey) - Static method in class org.apache.hadoop.security.token.SecretManager
- 
Compute HMAC of the identifier using the secret key and return the 
 output as password 
- createProvider(URI, Configuration) - Method in class org.apache.hadoop.crypto.key.JavaKeyStoreProvider.Factory
-  
- createProvider(URI, Configuration) - Method in class org.apache.hadoop.crypto.key.KeyProviderFactory
-  
- createProvider(URI, Configuration) - Method in class org.apache.hadoop.crypto.key.kms.KMSClientProvider.Factory
- 
This provider expects URIs in the following form :
 kms:// @/
 where :
 - PROTO = http or https
 - AUTHORITY = [:]
 - HOSTS = [;]
 - HOSTNAME = string
 - PORT = integer
 This will always create aLoadBalancingKMSClientProviderif the uri is correct.
- createProvider(URI, Configuration) - Method in class org.apache.hadoop.crypto.key.UserProvider.Factory
-  
- createProvider(URI, Configuration) - Method in class org.apache.hadoop.security.alias.CredentialProviderFactory
-  
- createProvider(URI, Configuration) - Method in class org.apache.hadoop.security.alias.JavaKeyStoreProvider.Factory
-  
- createProvider(URI, Configuration) - Method in class org.apache.hadoop.security.alias.LocalJavaKeyStoreProvider.Factory
-  
- createProvider(URI, Configuration) - Method in class org.apache.hadoop.security.alias.UserProvider.Factory
-  
- createProxyUser(String, UserGroupInformation) - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Create a proxy user using username of the effective user and the ugi of the
 real user. 
- createProxyUserForTesting(String, UserGroupInformation, String[]) - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Create a proxy user UGI for testing HDFS and MapReduce 
- createRecord(String) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- 
Deprecated. Creates a new AbstractMetricsRecord instance with the given recordName.
 
- createRemoteUser(String) - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Create a user from a login name. 
- createRemoteUser(String, SaslRpcServer.AuthMethod) - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Create a user from a login name. 
- createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class org.apache.hadoop.security.SaslPlainServer.SaslPlainServerFactory
-  
- createScanner() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get a scanner than can scan the whole TFile. 
- createScanner(byte[], byte[]) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
- createScanner(RawComparable, RawComparable) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
- createScannerByByteRange(long, long) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get a scanner that covers a portion of TFile based on byte offsets. 
- createScannerByKey(byte[], byte[]) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get a scanner that covers a portion of TFile based on keys. 
- createScannerByKey(RawComparable, RawComparable) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get a scanner that covers a specific key range. 
- createScannerByRecordNum(long, long) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Create a scanner that covers a range of records. 
- createSecretKey(byte[]) - Static method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
- 
Convert the byte[] to a secret key 
- createSecretKey(byte[]) - Static method in class org.apache.hadoop.security.token.SecretManager
- 
Convert the byte[] to a secret key 
- createSnapshot(Path, String) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
- createSnapshot(Path) - Method in class org.apache.hadoop.fs.FileContext
- 
Create a snapshot with a default name. 
- createSnapshot(Path, String) - Method in class org.apache.hadoop.fs.FileContext
- 
Create a snapshot. 
- createSnapshot(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create a snapshot with a default name. 
- createSnapshot(Path, String) - Method in class org.apache.hadoop.fs.FileSystem
- 
Create a snapshot. 
- createSnapshot(Path, String) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- createSnapshot(Path, String) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- createSnapshot(Path, String) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- createSocket() - Method in class org.apache.hadoop.metrics2.sink.StatsDSink.StatsD
-  
- createSocket() - Method in class org.apache.hadoop.net.SocksSocketFactory
-  
- createSocket(InetAddress, int) - Method in class org.apache.hadoop.net.SocksSocketFactory
-  
- createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.hadoop.net.SocksSocketFactory
-  
- createSocket(String, int) - Method in class org.apache.hadoop.net.SocksSocketFactory
-  
- createSocket(String, int, InetAddress, int) - Method in class org.apache.hadoop.net.SocksSocketFactory
-  
- createSocket() - Method in class org.apache.hadoop.net.StandardSocketFactory
-  
- createSocket(InetAddress, int) - Method in class org.apache.hadoop.net.StandardSocketFactory
-  
- createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.hadoop.net.StandardSocketFactory
-  
- createSocket(String, int) - Method in class org.apache.hadoop.net.StandardSocketFactory
-  
- createSocket(String, int, InetAddress, int) - Method in class org.apache.hadoop.net.StandardSocketFactory
-  
- createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
- createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.FileContext
- 
Creates a symbolic link to an existing file. 
- createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.FileSystem
- 
- createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.LocalFileSystem
-  
- createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- createUserForTesting(String, String[]) - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Create a UGI for testing HDFS and MapReduce 
- createValueBytes() - Method in class org.apache.hadoop.io.SequenceFile.Reader
-  
- createWriter(Configuration, SequenceFile.Writer.Option...) - Static method in class org.apache.hadoop.io.SequenceFile
- 
Create a new Writer with the given options. 
- createWriter(FileSystem, Configuration, Path, Class, Class) - Static method in class org.apache.hadoop.io.SequenceFile
- 
- createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.io.SequenceFile
- 
- createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, Progressable) - Static method in class org.apache.hadoop.io.SequenceFile
- 
- createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec) - Static method in class org.apache.hadoop.io.SequenceFile
- 
- createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec, Progressable, SequenceFile.Metadata) - Static method in class org.apache.hadoop.io.SequenceFile
- 
- createWriter(FileSystem, Configuration, Path, Class, Class, int, short, long, SequenceFile.CompressionType, CompressionCodec, Progressable, SequenceFile.Metadata) - Static method in class org.apache.hadoop.io.SequenceFile
- 
- createWriter(FileSystem, Configuration, Path, Class, Class, int, short, long, boolean, SequenceFile.CompressionType, CompressionCodec, SequenceFile.Metadata) - Static method in class org.apache.hadoop.io.SequenceFile
- 
Deprecated. 
- createWriter(FileContext, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec, SequenceFile.Metadata, EnumSet<CreateFlag>, Options.CreateOpts...) - Static method in class org.apache.hadoop.io.SequenceFile
- 
Construct the preferred type of SequenceFile Writer. 
- createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec, Progressable) - Static method in class org.apache.hadoop.io.SequenceFile
- 
- createWriter(Configuration, FSDataOutputStream, Class, Class, SequenceFile.CompressionType, CompressionCodec, SequenceFile.Metadata) - Static method in class org.apache.hadoop.io.SequenceFile
- 
- createWriter(Configuration, FSDataOutputStream, Class, Class, SequenceFile.CompressionType, CompressionCodec) - Static method in class org.apache.hadoop.io.SequenceFile
- 
- CREDENTIAL_PROVIDER_PATH - Static variable in class org.apache.hadoop.security.alias.CredentialProviderFactory
-  
- CredentialProvider - Class in org.apache.hadoop.security.alias
- 
A provider of credentials or password for Hadoop applications. 
- CredentialProvider() - Constructor for class org.apache.hadoop.security.alias.CredentialProvider
-  
- CredentialProvider.CredentialEntry - Class in org.apache.hadoop.security.alias
- 
The combination of both the alias and the actual credential value. 
- CredentialProvider.CredentialEntry(String, char[]) - Constructor for class org.apache.hadoop.security.alias.CredentialProvider.CredentialEntry
-  
- CredentialProviderFactory - Class in org.apache.hadoop.security.alias
- 
A factory to create a list of CredentialProvider based on the path given in a
 Configuration. 
- CredentialProviderFactory() - Constructor for class org.apache.hadoop.security.alias.CredentialProviderFactory
-  
- Credentials - Class in org.apache.hadoop.security
- 
A class that provides the facilities of reading and writing
 secret keys and Tokens. 
- Credentials() - Constructor for class org.apache.hadoop.security.Credentials
- 
Create an empty credentials instance 
- Credentials(Credentials) - Constructor for class org.apache.hadoop.security.Credentials
- 
Create a copy of the given credentials 
- CredentialShell - Class in org.apache.hadoop.security.alias
- 
This program is the CLI utility for the CredentialProvider facilities in 
 Hadoop. 
- CredentialShell() - Constructor for class org.apache.hadoop.security.alias.CredentialShell
-  
- CredentialShell.PasswordReader - Class in org.apache.hadoop.security.alias
- 
To facilitate testing since Console is a final class. 
- CredentialShell.PasswordReader() - Constructor for class org.apache.hadoop.security.alias.CredentialShell.PasswordReader
-  
- CrossOriginFilter - Class in org.apache.hadoop.security.http
-  
- CrossOriginFilter() - Constructor for class org.apache.hadoop.security.http.CrossOriginFilter
-  
- CryptoFSDataInputStream - Class in org.apache.hadoop.fs.crypto
-  
- CryptoFSDataInputStream(FSDataInputStream, CryptoCodec, int, byte[], byte[]) - Constructor for class org.apache.hadoop.fs.crypto.CryptoFSDataInputStream
-  
- CryptoFSDataInputStream(FSDataInputStream, CryptoCodec, byte[], byte[]) - Constructor for class org.apache.hadoop.fs.crypto.CryptoFSDataInputStream
-  
- CryptoFSDataOutputStream - Class in org.apache.hadoop.fs.crypto
-  
- CryptoFSDataOutputStream(FSDataOutputStream, CryptoCodec, int, byte[], byte[]) - Constructor for class org.apache.hadoop.fs.crypto.CryptoFSDataOutputStream
-  
- CryptoFSDataOutputStream(FSDataOutputStream, CryptoCodec, int, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.fs.crypto.CryptoFSDataOutputStream
-  
- CryptoFSDataOutputStream(FSDataOutputStream, CryptoCodec, byte[], byte[]) - Constructor for class org.apache.hadoop.fs.crypto.CryptoFSDataOutputStream
-  
- CSTRING_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
- 
Deprecated. 
- CsvRecordInput - Class in org.apache.hadoop.record
- 
- CsvRecordInput(InputStream) - Constructor for class org.apache.hadoop.record.CsvRecordInput
- 
Deprecated. Creates a new instance of CsvRecordInput 
- CsvRecordOutput - Class in org.apache.hadoop.record
- 
- CsvRecordOutput(OutputStream) - Constructor for class org.apache.hadoop.record.CsvRecordOutput
- 
Deprecated. Creates a new instance of CsvRecordOutput 
- CUR_DIR - Static variable in class org.apache.hadoop.fs.Path
- 
The current directory, ".". 
- curChar - Variable in class org.apache.hadoop.record.compiler.generated.RccTokenManager
- 
Deprecated. 
- currentConfig() - Method in interface org.apache.hadoop.metrics2.MetricsSystemMXBean
-  
- currentId - Variable in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
- 
Access to currentId is protected by this object lock. 
- currentToken - Variable in exception org.apache.hadoop.record.compiler.generated.ParseException
- 
Deprecated. This is the last token that has been consumed successfully. 
- currentTokens - Variable in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
- 
Cache of currently valid tokens, mapping from DelegationTokenIdentifier 
 to DelegationTokenInformation. 
- CUSTOM_HEADER_PARAM - Static variable in class org.apache.hadoop.security.http.RestCsrfPreventionFilter
-  
- CUSTOM_HEADER_PARAM - Static variable in class org.apache.hadoop.security.http.XFrameOptionsFilter
-  
- CUSTOM_METHODS_TO_IGNORE_PARAM - Static variable in class org.apache.hadoop.security.http.RestCsrfPreventionFilter
-  
- G_SIZE - Static variable in interface org.apache.hadoop.io.compress.bzip2.BZip2Constants
-  
- GangliaContext - Class in org.apache.hadoop.metrics.ganglia
- 
- GangliaContext() - Constructor for class org.apache.hadoop.metrics.ganglia.GangliaContext
- 
Deprecated. Creates a new instance of GangliaContext 
- GangliaContext31 - Class in org.apache.hadoop.metrics.ganglia
- 
- GangliaContext31() - Constructor for class org.apache.hadoop.metrics.ganglia.GangliaContext31
- 
Deprecated. 
- gangliaMetricVisitor - Variable in class org.apache.hadoop.metrics2.sink.ganglia.AbstractGangliaSink
- 
Used for visiting Metrics 
- GangliaSink30 - Class in org.apache.hadoop.metrics2.sink.ganglia
- 
This code supports Ganglia 3.0 
- GangliaSink30() - Constructor for class org.apache.hadoop.metrics2.sink.ganglia.GangliaSink30
-  
- GangliaSink31 - Class in org.apache.hadoop.metrics2.sink.ganglia
- 
This code supports Ganglia 3.1 
- GangliaSink31() - Constructor for class org.apache.hadoop.metrics2.sink.ganglia.GangliaSink31
-  
- gauge(MetricsInfo, int) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
- 
Callback for integer value gauges 
- gauge(MetricsInfo, long) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
- 
Callback for long value gauges 
- gauge(MetricsInfo, float) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
- 
Callback for float value gauges 
- gauge(MetricsInfo, double) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
- 
Callback for double value gauges 
- GcTimeMonitor - Class in org.apache.hadoop.util
- 
This class monitors the percentage of time the JVM is paused in GC within
 the specified observation window, say 1 minute. 
- GcTimeMonitor(long, long, int, GcTimeMonitor.GcTimeAlertHandler) - Constructor for class org.apache.hadoop.util.GcTimeMonitor
- 
Create an instance of GCTimeMonitor. 
- GcTimeMonitor.GcData - Class in org.apache.hadoop.util
- 
Encapsulates data about GC pauses measured at the specific timestamp. 
- GcTimeMonitor.GcData() - Constructor for class org.apache.hadoop.util.GcTimeMonitor.GcData
-  
- GcTimeMonitor.GcTimeAlertHandler - Interface in org.apache.hadoop.util
- 
The user can provide an instance of a class implementing this interface
 when initializing a GcTimeMonitor to receive alerts when GC time
 percentage exceeds the specified threshold. 
- genCode(String, String, ArrayList<String>) - Method in class org.apache.hadoop.record.compiler.JFile
- 
Deprecated. Generate record code in given language. 
- generateEncryptedKey(String) - Method in interface org.apache.hadoop.crypto.key.KeyProviderCryptoExtension.CryptoExtension
- 
Generates a key material and encrypts it using the given key version name
 and initialization vector. 
- generateEncryptedKey(String) - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- generateKey(int, String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Generates a key material. 
- generateParseException() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
- 
Deprecated. 
- generateSecret() - Method in class org.apache.hadoop.security.token.SecretManager
- 
Generate a new random secret key. 
- GENERIC_READ - Static variable in class org.apache.hadoop.io.nativeio.NativeIO.Windows
-  
- GENERIC_WRITE - Static variable in class org.apache.hadoop.io.nativeio.NativeIO.Windows
-  
- GenericRefreshProtocolClientSideTranslatorPB - Class in org.apache.hadoop.ipc.protocolPB
-  
- GenericRefreshProtocolClientSideTranslatorPB(GenericRefreshProtocolPB) - Constructor for class org.apache.hadoop.ipc.protocolPB.GenericRefreshProtocolClientSideTranslatorPB
-  
- GenericRefreshProtocolProtos - Class in org.apache.hadoop.ipc.proto
-  
- GenericRefreshProtocolProtos.GenericRefreshProtocolService - Class in org.apache.hadoop.ipc.proto
- 
Protobuf service hadoop.common.GenericRefreshProtocolService
 
- GenericRefreshProtocolProtos.GenericRefreshProtocolService() - Constructor for class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshProtocolService
-  
- GenericRefreshProtocolProtos.GenericRefreshProtocolService.BlockingInterface - Interface in org.apache.hadoop.ipc.proto
-  
- GenericRefreshProtocolProtos.GenericRefreshProtocolService.Interface - Interface in org.apache.hadoop.ipc.proto
-  
- GenericRefreshProtocolProtos.GenericRefreshProtocolService.Stub - Class in org.apache.hadoop.ipc.proto
-  
- GenericRefreshProtocolProtos.GenericRefreshRequestProto - Class in org.apache.hadoop.ipc.proto
- 
Protobuf type hadoop.common.GenericRefreshRequestProto
 
- GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder - Class in org.apache.hadoop.ipc.proto
- 
Protobuf type hadoop.common.GenericRefreshRequestProto
 
- GenericRefreshProtocolProtos.GenericRefreshRequestProtoOrBuilder - Interface in org.apache.hadoop.ipc.proto
-  
- GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto - Class in org.apache.hadoop.ipc.proto
- 
Protobuf type hadoop.common.GenericRefreshResponseCollectionProto
 
- GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder - Class in org.apache.hadoop.ipc.proto
- 
Protobuf type hadoop.common.GenericRefreshResponseCollectionProto
 
- GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProtoOrBuilder - Interface in org.apache.hadoop.ipc.proto
-  
- GenericRefreshProtocolProtos.GenericRefreshResponseProto - Class in org.apache.hadoop.ipc.proto
- 
Protobuf type hadoop.common.GenericRefreshResponseProto
 
- GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder - Class in org.apache.hadoop.ipc.proto
- 
Protobuf type hadoop.common.GenericRefreshResponseProto
 
- GenericRefreshProtocolProtos.GenericRefreshResponseProtoOrBuilder - Interface in org.apache.hadoop.ipc.proto
-  
- GenericRefreshProtocolServerSideTranslatorPB - Class in org.apache.hadoop.ipc.protocolPB
-  
- GenericRefreshProtocolServerSideTranslatorPB(GenericRefreshProtocol) - Constructor for class org.apache.hadoop.ipc.protocolPB.GenericRefreshProtocolServerSideTranslatorPB
-  
- GenericWritable - Class in org.apache.hadoop.io
- 
A wrapper for Writable instances. 
- GenericWritable() - Constructor for class org.apache.hadoop.io.GenericWritable
-  
- get(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty,nullif
 no such property exists.
 
- get(String, String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the name.
 
- get(URI, Configuration) - Static method in class org.apache.hadoop.crypto.key.KeyProviderFactory
- 
Create a KeyProvider based on a provided URI. 
- get(URI, Configuration) - Static method in class org.apache.hadoop.fs.AbstractFileSystem
- 
The main factory method for creating a file system. 
- get(int) - Method in interface org.apache.hadoop.fs.BatchedRemoteIterator.BatchedEntries
-  
- get(int) - Method in class org.apache.hadoop.fs.BatchedRemoteIterator.BatchedListEntries
-  
- get(URI, Configuration, String) - Static method in class org.apache.hadoop.fs.FileSystem
- 
Get a FileSystem instance based on the uri, the passed in
 configuration and the user. 
- get(Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
- 
Returns the configured FileSystem implementation. 
- get(URI, Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
- 
Get a FileSystem for this URI's scheme and authority. 
- get(String) - Method in enum org.apache.hadoop.fs.GlobalStorageStatistics
- 
Get the StorageStatistics object with the given name. 
- get(long, Writable) - Method in class org.apache.hadoop.io.ArrayFile.Reader
- 
Return the nth value in the file.
 
- get() - Method in class org.apache.hadoop.io.ArrayPrimitiveWritable
- 
Get the original array. 
- get() - Method in class org.apache.hadoop.io.ArrayWritable
-  
- get(WritableComparable, Writable) - Method in class org.apache.hadoop.io.BloomMapFile.Reader
- 
- get() - Method in class org.apache.hadoop.io.BooleanWritable
- 
Returns the value of the BooleanWritable 
- get() - Method in class org.apache.hadoop.io.BytesWritable
- 
- get() - Method in class org.apache.hadoop.io.ByteWritable
- 
Return the value of this ByteWritable. 
- get() - Method in class org.apache.hadoop.io.DoubleWritable
-  
- get() - Method in class org.apache.hadoop.io.EnumSetWritable
- 
Return the value of this EnumSetWritable. 
- get(BytesWritable, BytesWritable) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Copy the key and value in one shot into BytesWritables. 
- get() - Method in class org.apache.hadoop.io.FloatWritable
- 
Return the value of this FloatWritable. 
- get() - Method in class org.apache.hadoop.io.GenericWritable
- 
Return the wrapped instance. 
- get() - Method in class org.apache.hadoop.io.IntWritable
- 
Return the value of this IntWritable. 
- get() - Method in class org.apache.hadoop.io.LongWritable
- 
Return the value of this LongWritable. 
- get(WritableComparable, Writable) - Method in class org.apache.hadoop.io.MapFile.Reader
- 
Return the value for the named key, or null if none exists. 
- get(Object) - Method in class org.apache.hadoop.io.MapWritable
-  
- get() - Static method in class org.apache.hadoop.io.NullWritable
- 
Returns the single instance of this class. 
- get() - Method in class org.apache.hadoop.io.ObjectWritable
- 
Return the instance, or null if none. 
- get(Text) - Method in class org.apache.hadoop.io.SequenceFile.Metadata
-  
- get(WritableComparable) - Method in class org.apache.hadoop.io.SetFile.Reader
- 
Read the matching key from a set into key.
 
- get() - Method in class org.apache.hadoop.io.ShortWritable
- 
Return the value of this ShortWritable. 
- get(Object) - Method in class org.apache.hadoop.io.SortedMapWritable
-  
- get() - Method in class org.apache.hadoop.io.TwoDArrayWritable
-  
- get() - Method in class org.apache.hadoop.io.VIntWritable
- 
Return the value of this VIntWritable. 
- get() - Method in class org.apache.hadoop.io.VLongWritable
- 
Return the value of this LongWritable. 
- get(Class<? extends WritableComparable>) - Static method in class org.apache.hadoop.io.WritableComparator
- 
For backwards compatibility. 
- get(Class<? extends WritableComparable>, Configuration) - Static method in class org.apache.hadoop.io.WritableComparator
- 
- get() - Method in class org.apache.hadoop.ipc.ExternalCall
-  
- get() - Static method in class org.apache.hadoop.ipc.Server
- 
Returns the server instance called under or null. 
- get(String) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
- 
Get a metric by name 
- get(String, Collection<MetricsTag>) - Method in class org.apache.hadoop.metrics2.util.MetricsCache
- 
Get the cached record 
- get(DataInput) - Static method in class org.apache.hadoop.record.BinaryRecordInput
- 
Deprecated. Get a thread-local record input for the supplied DataInput. 
- get(DataOutput) - Static method in class org.apache.hadoop.record.BinaryRecordOutput
- 
Deprecated. Get a thread-local record output for the supplied DataOutput. 
- get() - Method in class org.apache.hadoop.record.Buffer
- 
Deprecated. Get the data from the Buffer. 
- get(long, TimeUnit) - Method in interface org.apache.hadoop.util.concurrent.AsyncGet
- 
Get the result. 
- get() - Method in class org.apache.hadoop.util.concurrent.AsyncGetFuture
-  
- get(long, TimeUnit) - Method in class org.apache.hadoop.util.concurrent.AsyncGetFuture
-  
- get() - Static method in class org.apache.hadoop.util.ShutdownHookManager
- 
Return ShutdownHookManagersingleton.
 
- getAccessTime() - Method in class org.apache.hadoop.fs.FileStatus
- 
Get the access time of the file. 
- getAccumulatedGcCount() - Method in class org.apache.hadoop.util.GcTimeMonitor.GcData
- 
Returns the accumulated number of GC pauses since this JVM started. 
- getAccumulatedGcTime() - Method in class org.apache.hadoop.util.GcTimeMonitor.GcData
- 
Returns accumulated GC time since this JVM started. 
- getAclBit() - Method in class org.apache.hadoop.fs.permission.FsPermission
- 
Returns true if there is also an ACL (access control list). 
- getAclStatus(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Gets the ACLs of files and directories. 
- getAclStatus(Path) - Method in class org.apache.hadoop.fs.FileContext
- 
Gets the ACLs of files and directories. 
- getAclStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Gets the ACL of a file or directory. 
- getAclStatus(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getAclStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getAclStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getAclString() - Method in class org.apache.hadoop.security.authorize.AccessControlList
- 
Returns the access control list as a String that can be used for building a
 new instance by sending it to the constructor of  AccessControlList. 
- getAddress() - Method in class org.apache.hadoop.ha.HAServiceTarget
-  
- getAdjustedEnd() - Method in class org.apache.hadoop.io.compress.SplitCompressionInputStream
- 
After calling createInputStream, the values of start or end
 might change. 
- getAdjustedStart() - Method in class org.apache.hadoop.io.compress.SplitCompressionInputStream
- 
After calling createInputStream, the values of start or end
 might change. 
- getAlgorithm() - Method in class org.apache.hadoop.crypto.key.JavaKeyStoreProvider.KeyMetadata
-  
- getAlgorithm() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Metadata
- 
Get the algorithm from the cipher. 
- getAlgorithmName() - Method in class org.apache.hadoop.fs.FileChecksum
- 
The checksum algorithm name 
- getAlias() - Method in class org.apache.hadoop.security.alias.CredentialProvider.CredentialEntry
-  
- getAliases() - Method in class org.apache.hadoop.security.alias.CredentialProvider
- 
Get the aliases for all credentials. 
- getAllKeys() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
-  
- getAllRecords() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- 
Deprecated. Retrieves all the records managed by this MetricsContext. 
- getAllSecretKeys() - Method in class org.apache.hadoop.security.Credentials
- 
Return all the secret key entries in the in-memory map 
- getAllShells() - Static method in class org.apache.hadoop.util.Shell
- 
Static method to return a Set of all Shellobjects.
 
- getAllStatistics() - Static method in class org.apache.hadoop.fs.AbstractFileSystem
-  
- getAllStatistics() - Static method in class org.apache.hadoop.fs.FileContext
-  
- getAllStatistics() - Static method in class org.apache.hadoop.fs.FileSystem
- 
- getAllStoragePolicies() - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Retrieve all the storage policies supported by this file system. 
- getAllStoragePolicies() - Method in class org.apache.hadoop.fs.FileContext
- 
Retrieve all the storage policies supported by this file system. 
- getAllStoragePolicies() - Method in class org.apache.hadoop.fs.FileSystem
- 
Retrieve all the storage policies supported by this file system. 
- getAllStoragePolicies() - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getAllTokens() - Method in class org.apache.hadoop.security.Credentials
- 
Return all the tokens in the in-memory map 
- getAndAdvanceCurrentIndex() - Method in interface org.apache.hadoop.ipc.RpcMultiplexer
- 
Should get current index and optionally perform whatever is needed
 to prepare the next index. 
- getAndAdvanceCurrentIndex() - Method in class org.apache.hadoop.ipc.WeightedRoundRobinMultiplexer
- 
Use the mux by getting and advancing index. 
- getApproxChkSumLength(long) - Static method in class org.apache.hadoop.fs.ChecksumFileSystem
-  
- getArgs(int) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
- 
repeated string args = 2;
 
- getArgs(int) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
- 
repeated string args = 2;
 
- getArgs(int) - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProtoOrBuilder
- 
repeated string args = 2;
 
- getArgsBytes(int) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
- 
repeated string args = 2;
 
- getArgsBytes(int) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
- 
repeated string args = 2;
 
- getArgsBytes(int) - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProtoOrBuilder
- 
repeated string args = 2;
 
- getArgsCount() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
- 
repeated string args = 2;
 
- getArgsCount() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
- 
repeated string args = 2;
 
- getArgsCount() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProtoOrBuilder
- 
repeated string args = 2;
 
- getArgsList() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
- 
repeated string args = 2;
 
- getArgsList() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
- 
repeated string args = 2;
 
- getArgsList() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProtoOrBuilder
- 
repeated string args = 2;
 
- getArgument(int) - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
- 
Returns the argument at the given position (starting from 1). 
- getArguments() - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
- 
Returns the arguments of this expression 
- getAsyncReturnMessage() - Static method in class org.apache.hadoop.ipc.ProtobufRpcEngine
-  
- getAsyncRpcResponse() - Static method in class org.apache.hadoop.ipc.Client
-  
- getAttribute(String) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- 
Deprecated. Convenience method for subclasses to access factory attributes. 
- getAttributes() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Metadata
-  
- getAttributes() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Options
-  
- getAttributeTable(String) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- 
Deprecated. Returns an attribute-value map derived from the factory attributes
 by finding all factory attributes that begin with 
 contextName.tableName. 
- getAuthenticationMethod(Configuration) - Static method in class org.apache.hadoop.security.SecurityUtil
-  
- getAuthenticationMethod() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Get the authentication method from the subject 
- getAuthMethod() - Method in enum org.apache.hadoop.security.UserGroupInformation.AuthenticationMethod
-  
- getAuths(int) - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuths(int) - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuths(int) - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsBuilder(int) - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsBuilderList() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsCount() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsList() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsList() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsList() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsOrBuilder(int) - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsOrBuilder(int) - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsOrBuilder(int) - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsOrBuilderList() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsOrBuilderList() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuthsOrBuilderList() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
repeated .hadoop.common.RpcSaslProto.SaslAuth auths = 4;
 
- getAuxiliaryListenerAddresses() - Method in class org.apache.hadoop.ipc.Server
- 
Return the set of all the configured auxiliary socket addresses NameNode
 RPC is listening on. 
- getAuxiliaryPortEstablishedQOP() - Static method in class org.apache.hadoop.ipc.Server
- 
Returns the SASL qop for the current call, if the current call is
 set, and the SASL negotiation is done. 
- getAvailablePhysicalMemorySize() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the total size of the available physical memory present
 in the system. 
- getAvailableVirtualMemorySize() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the total size of the available virtual memory present
 in the system. 
- getAverageResponseTime() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler
-  
- getAverageResponseTime() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler.MetricsProxy
-  
- getAverageResponseTime() - Method in interface org.apache.hadoop.ipc.DecayRpcSchedulerMXBean
-  
- getBaseName(String) - Static method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Split the versionName in to a base name. 
- getBeginColumn() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
- 
Deprecated. 
- getBeginLine() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
- 
Deprecated. 
- getBestUGI(String, String) - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Find the most appropriate UserGroupInformation to use 
- getBitLength() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Metadata
-  
- getBitLength() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Options
-  
- getBlockers() - Method in class org.apache.hadoop.service.AbstractService
-  
- getBlockers() - Method in interface org.apache.hadoop.service.Service
- 
Get the blockers on a service -remote dependencies
 that are stopping the service from being live. 
- getBlockLocations() - Method in class org.apache.hadoop.fs.LocatedFileStatus
- 
Get the file's block locations 
- getBlockSize() - Method in class org.apache.hadoop.fs.FileStatus
- 
Get the block size of the file. 
- getBlockSize(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
- getBlockSize() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
-  
- getBlockSize() - Method in class org.apache.hadoop.fs.FsServerDefaults
-  
- getBlockSize(Configuration) - Static method in class org.apache.hadoop.io.compress.bzip2.Bzip2Factory
-  
- getBlockSize() - Method in class org.apache.hadoop.io.compress.bzip2.CBZip2OutputStream
- 
Returns the blocksize parameter specified at construction time. 
- getBloomFilter() - Method in class org.apache.hadoop.io.BloomMapFile.Reader
- 
Retrieve the Bloom filter used by this instance of the Reader. 
- getBoolean(String, boolean) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as aboolean.
 
- getBranch() - Static method in class org.apache.hadoop.util.VersionInfo
- 
Get the branch on which this originated. 
- getBuffer(boolean, int) - Method in interface org.apache.hadoop.io.ByteBufferPool
- 
Get a new direct ByteBuffer. 
- getBuffer(boolean, int) - Method in class org.apache.hadoop.io.ElasticByteBufferPool
-  
- getBufferSize() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
-  
- getBuildVersion() - Static method in class org.apache.hadoop.util.VersionInfo
- 
Returns the buildVersion which includes version,
 revision, user and date. 
- getByName(String) - Method in class org.apache.hadoop.security.SecurityUtil.QualifiedHostResolver
- 
Create an InetAddress with a fully qualified hostname of the given
 hostname. 
- getByName(String) - Method in class org.apache.hadoop.util.MachineList.InetAddressFactory
-  
- getBytes() - Method in class org.apache.hadoop.fs.FileChecksum
- 
The value of the checksum in bytes 
- getBytes() - Method in class org.apache.hadoop.io.BinaryComparable
- 
Return representative byte array for this instance. 
- getBytes() - Method in class org.apache.hadoop.io.BytesWritable
- 
Get the data backing the BytesWritable. 
- getBytes() - Method in class org.apache.hadoop.io.Text
- 
- getBytes() - Method in class org.apache.hadoop.security.token.TokenIdentifier
- 
Get the bytes for the token identifier 
- getBytesPerChecksum() - Method in class org.apache.hadoop.fs.FsServerDefaults
-  
- getBytesPerChecksum() - Method in class org.apache.hadoop.fs.Options.ChecksumOpt
-  
- getBytesPerSum() - Method in class org.apache.hadoop.fs.ChecksumFileSystem
- 
Return the bytes Per Checksum 
- getBytesRead() - Method in class org.apache.hadoop.fs.FileSystem.Statistics
- 
Get the total number of bytes read. 
- getBytesRead() - Method in class org.apache.hadoop.fs.FileSystem.Statistics.StatisticsData
-  
- getBytesRead() - Method in class org.apache.hadoop.io.compress.bzip2.Bzip2Compressor
- 
Returns the total number of uncompressed bytes input so far. 
- getBytesRead() - Method in class org.apache.hadoop.io.compress.bzip2.Bzip2Decompressor
- 
Returns the total number of compressed bytes input so far. 
- getBytesRead() - Method in class org.apache.hadoop.io.compress.bzip2.BZip2DummyCompressor
-  
- getBytesRead() - Method in interface org.apache.hadoop.io.compress.Compressor
- 
Return number of uncompressed bytes input so far. 
- getBytesRead() - Method in class org.apache.hadoop.io.compress.lz4.Lz4Compressor
- 
Return number of bytes given to this compressor since last reset. 
- getBytesRead() - Method in class org.apache.hadoop.io.compress.snappy.SnappyCompressor
- 
Return number of bytes given to this compressor since last reset. 
- getBytesRead() - Method in class org.apache.hadoop.io.compress.zlib.BuiltInGzipDecompressor
- 
Returns the total number of compressed bytes input so far, including
 gzip header/trailer bytes. 
- getBytesRead() - Method in class org.apache.hadoop.io.compress.zlib.ZlibCompressor
- 
Returns the total number of uncompressed bytes input so far. 
- getBytesRead() - Method in class org.apache.hadoop.io.compress.zlib.ZlibDecompressor
- 
Returns the total number of compressed bytes input so far. 
- getBytesRead() - Method in class org.apache.hadoop.io.compress.zstd.ZStandardCompressor
- 
Returns the total number of uncompressed bytes input so far. 
- getBytesReadByDistance(int) - Method in class org.apache.hadoop.fs.FileSystem.Statistics
- 
In the common network topology setup, distance value should be an even
 number such as 0, 2, 4, 6. 
- getBytesReadDistanceOfFiveOrLarger() - Method in class org.apache.hadoop.fs.FileSystem.Statistics.StatisticsData
-  
- getBytesReadDistanceOfOneOrTwo() - Method in class org.apache.hadoop.fs.FileSystem.Statistics.StatisticsData
-  
- getBytesReadDistanceOfThreeOrFour() - Method in class org.apache.hadoop.fs.FileSystem.Statistics.StatisticsData
-  
- getBytesReadLocalHost() - Method in class org.apache.hadoop.fs.FileSystem.Statistics.StatisticsData
-  
- getBytesWritten() - Method in class org.apache.hadoop.fs.FileSystem.Statistics
- 
Get the total number of bytes written. 
- getBytesWritten() - Method in class org.apache.hadoop.fs.FileSystem.Statistics.StatisticsData
-  
- getBytesWritten() - Method in class org.apache.hadoop.io.compress.bzip2.Bzip2Compressor
- 
Returns the total number of compressed bytes output so far. 
- getBytesWritten() - Method in class org.apache.hadoop.io.compress.bzip2.Bzip2Decompressor
- 
Returns the total number of uncompressed bytes output so far. 
- getBytesWritten() - Method in class org.apache.hadoop.io.compress.bzip2.BZip2DummyCompressor
-  
- getBytesWritten() - Method in interface org.apache.hadoop.io.compress.Compressor
- 
Return number of compressed bytes output so far. 
- getBytesWritten() - Method in class org.apache.hadoop.io.compress.lz4.Lz4Compressor
- 
Return number of bytes consumed by callers of compress since last reset. 
- getBytesWritten() - Method in class org.apache.hadoop.io.compress.snappy.SnappyCompressor
- 
Return number of bytes consumed by callers of compress since last reset. 
- getBytesWritten() - Method in class org.apache.hadoop.io.compress.zlib.ZlibCompressor
- 
Returns the total number of compressed bytes output so far. 
- getBytesWritten() - Method in class org.apache.hadoop.io.compress.zlib.ZlibDecompressor
- 
Returns the total number of uncompressed bytes output so far. 
- getBytesWritten() - Method in class org.apache.hadoop.io.compress.zstd.ZStandardCompressor
- 
Returns the total number of compressed bytes output so far. 
- getBzip2Compressor(Configuration) - Static method in class org.apache.hadoop.io.compress.bzip2.Bzip2Factory
- 
Return the appropriate implementation of the bzip2 compressor. 
- getBzip2CompressorType(Configuration) - Static method in class org.apache.hadoop.io.compress.bzip2.Bzip2Factory
- 
Return the appropriate type of the bzip2 compressor. 
- getBzip2Decompressor(Configuration) - Static method in class org.apache.hadoop.io.compress.bzip2.Bzip2Factory
- 
Return the appropriate implementation of the bzip2 decompressor. 
- getBzip2DecompressorType(Configuration) - Static method in class org.apache.hadoop.io.compress.bzip2.Bzip2Factory
- 
Return the appropriate type of the bzip2 decompressor. 
- getCachedHosts() - Method in class org.apache.hadoop.fs.BlockLocation
- 
Get the list of hosts (hostname) hosting a cached replica of the block 
- getCacheManipulator() - Static method in class org.apache.hadoop.io.nativeio.NativeIO.POSIX
-  
- getCachePoolDefault() - Static method in class org.apache.hadoop.fs.permission.FsPermission
- 
Get the default permission for cache pools. 
- getCallerContext() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- getCallerContext() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- getCallerContext() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- getCallerContextBuilder() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- getCallerContextOrBuilder() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- getCallerContextOrBuilder() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- getCallerContextOrBuilder() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- getCallId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
required sint32 callId = 3;
 
- getCallId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
required sint32 callId = 3;
 
- getCallId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
required sint32 callId = 3;
 
- getCallId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
required uint32 callId = 1;
 
- getCallId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
required uint32 callId = 1;
 
- getCallId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
required uint32 callId = 1;
 
- getCallId() - Static method in class org.apache.hadoop.ipc.Server
- 
Returns the currently active RPC call's sequential ID number. 
- getCallQueueLen() - Method in class org.apache.hadoop.ipc.Server
- 
The number of rpc calls in the queue. 
- getCallRetryCount() - Static method in class org.apache.hadoop.ipc.Server
-  
- getCallVolumeSummary() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler
-  
- getCallVolumeSummary() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler.MetricsProxy
-  
- getCallVolumeSummary() - Method in interface org.apache.hadoop.ipc.DecayRpcSchedulerMXBean
-  
- getCanonicalServiceName() - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Get a canonical name for this file system. 
- getCanonicalServiceName() - Method in class org.apache.hadoop.fs.FileSystem
- 
Get a canonical service name for this FileSystem. 
- getCanonicalUri() - Method in class org.apache.hadoop.fs.FileSystem
- 
Return a canonicalized form of this FileSystem's URI. 
- getCanonicalUri() - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getCanonicalUri() - Method in class org.apache.hadoop.fs.HarFileSystem
- 
Used for delegation token related functionality. 
- getCapacity() - Method in class org.apache.hadoop.fs.FsStatus
- 
Return the capacity in bytes of the file system 
- getCapacity() - Method in class org.apache.hadoop.io.BytesWritable
- 
Get the capacity, which is the maximum size that could handled without
 resizing the backing storage. 
- getCapacity() - Method in class org.apache.hadoop.record.Buffer
- 
Deprecated. Get the capacity, which is the maximum count that could handled without
 resizing the backing storage. 
- getCategory() - Method in exception org.apache.hadoop.security.KDiag.KerberosDiagsFailure
-  
- getChallenge() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional bytes challenge = 5;
 
- getChallenge() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
optional bytes challenge = 5;
 
- getChallenge() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
optional bytes challenge = 5;
 
- getChangedProperties(Configuration, Configuration) - Method in class org.apache.hadoop.conf.ReconfigurableBase
-  
- getChangedProperties(Configuration, Configuration) - Static method in class org.apache.hadoop.conf.ReconfigurationUtil
-  
- getChannel() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService.Stub
-  
- getChannel() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService.Stub
-  
- getChannel() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshProtocolService.Stub
-  
- getChannel() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueProtocolService.Stub
-  
- getChannel() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService.Stub
-  
- getChannel() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshAuthorizationPolicyProtocolService.Stub
-  
- getChannel() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserMappingsProtocolService.Stub
-  
- getChannel() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService.Stub
-  
- getChannel() - Method in class org.apache.hadoop.tracing.TraceAdminPB.TraceAdminService.Stub
-  
- getCheckProcessIsAliveCommand(String) - Static method in class org.apache.hadoop.util.Shell
- 
Return a command for determining if process with specified pid is alive. 
- getChecksumFile(Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
- 
Return the name of the checksum file associated with a file. 
- getChecksumFileLength(Path, long) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
- 
Return the length of the checksum file given the size of the 
 actual file. 
- getChecksumLength(long, int) - Static method in class org.apache.hadoop.fs.ChecksumFileSystem
- 
Calculated the length of the checksum file in bytes. 
- getChecksumOpt() - Method in class org.apache.hadoop.fs.FileChecksum
-  
- getChecksumOpt() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
-  
- getChecksumType() - Method in class org.apache.hadoop.fs.FsServerDefaults
-  
- getChecksumType() - Method in class org.apache.hadoop.fs.Options.ChecksumOpt
-  
- getChildFileSystems() - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getChildFileSystems() - Method in class org.apache.hadoop.fs.HarFileSystem
- 
Used for delegation token related functionality. 
- getChildFileSystems() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getChildren() - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
- 
Returns the children of this expression. 
- getChildren() - Method in class org.apache.hadoop.net.InnerNodeImpl
-  
- getCipher() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Metadata
-  
- getCipher() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Options
-  
- getClass(String, Class<?>) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as aClass.
 
- getClass(String, Class<? extends U>, Class<U>) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as aClassimplementing the interface specified byxface.
 
- getClass(byte) - Method in class org.apache.hadoop.io.AbstractMapWritable
-  
- getClass(T) - Static method in class org.apache.hadoop.util.ReflectionUtils
- 
Return the correctly-typed  Class of the given object. 
- getClassByName(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Load a class by name. 
- getClassByNameOrNull(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Load a class by name, returning null rather than throwing an exception
 if it couldn't be loaded. 
- getClasses(String, Class<?>...) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty
 as an array ofClass.
 
- getClassLoader() - Method in class org.apache.hadoop.conf.Configuration
- 
- getClassLoader() - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Override point: get the classloader to use. 
- getClassName() - Method in exception org.apache.hadoop.ipc.RemoteException
-  
- getClassName() - Method in class org.apache.hadoop.tracing.SpanReceiverInfo
-  
- getClassName() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
required string className = 1;
 
- getClassName() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
- 
required string className = 1;
 
- getClassName() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProtoOrBuilder
- 
required string className = 1;
 
- getClassName() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
- 
required string className = 2;
 
- getClassName() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
- 
required string className = 2;
 
- getClassName() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfoOrBuilder
- 
required string className = 2;
 
- getClassNameBytes() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
required string className = 1;
 
- getClassNameBytes() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
- 
required string className = 1;
 
- getClassNameBytes() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProtoOrBuilder
- 
required string className = 1;
 
- getClassNameBytes() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
- 
required string className = 2;
 
- getClassNameBytes() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
- 
required string className = 2;
 
- getClassNameBytes() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfoOrBuilder
- 
required string className = 2;
 
- getClientExecutor() - Static method in class org.apache.hadoop.ipc.Client
-  
- getClientId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
required bytes clientId = 4;
 
- getClientId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
required bytes clientId = 4;
 
- getClientId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
required bytes clientId = 4;
 
- getClientId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional bytes clientId = 7;
 
- getClientId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional bytes clientId = 7;
 
- getClientId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional bytes clientId = 7;
 
- getClientId() - Static method in class org.apache.hadoop.ipc.Server
- 
Returns the clientId from the current RPC request 
- getClientProperties(InetAddress) - Method in class org.apache.hadoop.security.SaslPropertiesResolver
- 
Identify the Sasl Properties to be used for a connection with a server. 
- getClientProperties(InetAddress, int) - Method in class org.apache.hadoop.security.SaslPropertiesResolver
- 
Identify the Sasl Properties to be used for a connection with a server. 
- getClientProtocolVersion() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required uint64 clientProtocolVersion = 3;
 
- getClientProtocolVersion() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
- 
required uint64 clientProtocolVersion = 3;
 
- getClientProtocolVersion() - Method in interface org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProtoOrBuilder
- 
required uint64 clientProtocolVersion = 3;
 
- getClientProtocolVersion() - Method in class org.apache.hadoop.ipc.ProtobufRpcEngine.Invoker
-  
- getClientStateId() - Method in class org.apache.hadoop.ipc.Server.Call
-  
- getClientVersion() - Method in exception org.apache.hadoop.ipc.RPC.VersionMismatch
- 
Get the client's preferred version 
- getClosest(WritableComparable, Writable) - Method in class org.apache.hadoop.io.MapFile.Reader
- 
Finds the record that is the closest match to the specified key. 
- getClosest(WritableComparable, Writable, boolean) - Method in class org.apache.hadoop.io.MapFile.Reader
- 
Finds the record that is the closest match to the specified key. 
- getCNs(X509Certificate) - Static method in class org.apache.hadoop.security.ssl.SSLHostnameVerifier.Certificates
-  
- getCodec(Path) - Method in class org.apache.hadoop.io.compress.CompressionCodecFactory
- 
Find the relevant compression codec for the given file based on its
 filename suffix. 
- getCodecByClassName(String) - Method in class org.apache.hadoop.io.compress.CompressionCodecFactory
- 
Find the relevant compression codec for the codec's canonical class name. 
- getCodecByName(String) - Method in class org.apache.hadoop.io.compress.CompressionCodecFactory
- 
Find the relevant compression codec for the codec's canonical class name
 or by codec alias. 
- getCodecClassByName(String) - Method in class org.apache.hadoop.io.compress.CompressionCodecFactory
- 
Find the relevant compression codec for the codec's canonical class name
 or by codec alias and returns its implemetation class. 
- getCodecClasses(Configuration) - Static method in class org.apache.hadoop.io.compress.CompressionCodecFactory
- 
Get the list of codecs discovered via a Java ServiceLoader, or
 listed in the configuration. 
- getCollection() - Method in class org.apache.hadoop.util.MachineList
- 
returns the contents of the MachineList as a Collection
 This can be used for testing 
- getCommandFactory() - Method in class org.apache.hadoop.fs.shell.find.FindOptions
- 
Return the command factory. 
- getComparator() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get an instance of the RawComparator that is constructed based on the
 string comparator representation. 
- getComparatorName() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get the string representation of the comparator. 
- getComponentType() - Method in class org.apache.hadoop.io.ArrayPrimitiveWritable
-  
- getCompressedData() - Method in class org.apache.hadoop.io.compress.BlockDecompressorStream
-  
- getCompressedData() - Method in class org.apache.hadoop.io.compress.DecompressorStream
-  
- getCompressionAlgorithmByName(String) - Static method in class org.apache.hadoop.io.file.tfile.Compression
-  
- getCompressionBufferSize(Configuration) - Static method in class org.apache.hadoop.io.compress.ZStandardCodec
-  
- getCompressionCodec() - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Returns the compression codec of data in this file. 
- getCompressionCodec() - Method in class org.apache.hadoop.io.SequenceFile.Writer
- 
Returns the compression codec of data in this file. 
- getCompressionLevel(Configuration) - Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
-  
- getCompressionLevel(Configuration) - Static method in class org.apache.hadoop.io.compress.ZStandardCodec
-  
- getCompressionStrategy(Configuration) - Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
-  
- getCompressionType() - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Get the compression type for this file. 
- getCompressor(CompressionCodec, Configuration) - Static method in class org.apache.hadoop.io.compress.CodecPool
- 
- getCompressor(CompressionCodec) - Static method in class org.apache.hadoop.io.compress.CodecPool
-  
- getCompressor() - Method in enum org.apache.hadoop.io.file.tfile.Compression.Algorithm
-  
- getCompressorType() - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
- getCompressorType() - Method in interface org.apache.hadoop.io.compress.CompressionCodec
- 
- getCompressorType() - Method in class org.apache.hadoop.io.compress.DefaultCodec
-  
- getCompressorType() - Method in class org.apache.hadoop.io.compress.GzipCodec
-  
- getCompressorType() - Method in class org.apache.hadoop.io.compress.Lz4Codec
- 
- getCompressorType() - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
- getCompressorType() - Method in class org.apache.hadoop.io.compress.ZStandardCodec
- 
- getConf() - Method in interface org.apache.hadoop.conf.Configurable
- 
Return the configuration used by this object. 
- getConf() - Method in class org.apache.hadoop.conf.Configured
-  
- getConf() - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Return the provider configuration. 
- getConf() - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getConf() - Method in class org.apache.hadoop.fs.GetSpaceUsed.Builder
-  
- getConf() - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getConf() - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
-  
- getConf() - Method in class org.apache.hadoop.fs.shell.find.FilterExpression
-  
- getConf() - Method in class org.apache.hadoop.io.AbstractMapWritable
-  
- getConf() - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
Return the configuration used by this object. 
- getConf() - Method in class org.apache.hadoop.io.compress.DefaultCodec
-  
- getConf() - Method in class org.apache.hadoop.io.compress.Lz4Codec
- 
Return the configuration used by this object. 
- getConf() - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
Return the configuration used by this object. 
- getConf() - Method in class org.apache.hadoop.io.compress.ZStandardCodec
- 
Return the configuration used by this object. 
- getConf() - Method in class org.apache.hadoop.io.EnumSetWritable
-  
- getConf() - Method in class org.apache.hadoop.io.GenericWritable
-  
- getConf() - Method in class org.apache.hadoop.io.ObjectWritable
-  
- getConf() - Method in class org.apache.hadoop.io.WritableComparator
-  
- getConf() - Method in class org.apache.hadoop.net.AbstractDNSToSwitchMapping
-  
- getConf() - Method in class org.apache.hadoop.net.ScriptBasedMapping
-  
- getConf() - Method in class org.apache.hadoop.net.SocksSocketFactory
-  
- getConf() - Method in class org.apache.hadoop.net.TableMapping
-  
- getConf() - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
-  
- getConf() - Method in class org.apache.hadoop.security.SaslPropertiesResolver
-  
- getConfig() - Method in class org.apache.hadoop.service.AbstractService
-  
- getConfig() - Method in interface org.apache.hadoop.service.Service
- 
Get the configuration of this service. 
- getConfig(int) - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfig(int) - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfig(int) - Method in interface org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProtoOrBuilder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigBuilder(int) - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigBuilderList() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigCount() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigCount() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigCount() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProtoOrBuilder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigList() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigList() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigList() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProtoOrBuilder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigOrBuilder(int) - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigOrBuilder(int) - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigOrBuilder(int) - Method in interface org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProtoOrBuilder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigOrBuilderList() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigOrBuilderList() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfigOrBuilderList() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProtoOrBuilder
- 
repeated .hadoop.common.ConfigPair config = 2;
 
- getConfiguration() - Method in class org.apache.hadoop.fs.shell.find.FindOptions
- 
- getConfiguration() - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Get the configuration constructed from the command line arguments. 
- getConfigurationsToCreate() - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Override point: Get a list of configuration classes to create. 
- getConfigViewFsPrefix(String) - Static method in class org.apache.hadoop.fs.viewfs.ConfigUtil
- 
Get the config variable prefix for the specified mount table 
- getConfigViewFsPrefix() - Static method in class org.apache.hadoop.fs.viewfs.ConfigUtil
- 
Get the config variable prefix for the default mount table 
- getConfResourceAsInputStream(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get an input stream attached to the configuration resource with the
 given name.
 
- getConfResourceAsReader(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get a  Reader attached to the configuration resource with the
 given  name. 
- getConnectionId() - Method in class org.apache.hadoop.ipc.ProtobufRpcEngine.Invoker
-  
- getConnectionId() - Method in interface org.apache.hadoop.ipc.RpcInvocationHandler
- 
Returns the connection id associated with the InvocationHandler instance. 
- getCons() - Method in class org.apache.hadoop.fs.GetSpaceUsed.Builder
-  
- getContentSummary(Path) - Method in class org.apache.hadoop.fs.FileContext.Util
- 
- getContentSummary(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
- getContentSummary(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getContentType() - Method in class org.apache.hadoop.log.Log4Json
-  
- getContext() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
- 
required string context = 1;
 
- getContext() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
- 
required string context = 1;
 
- getContext() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProtoOrBuilder
- 
required string context = 1;
 
- getContextBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
- 
required string context = 1;
 
- getContextBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
- 
required string context = 1;
 
- getContextBytes() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProtoOrBuilder
- 
required string context = 1;
 
- getContextFactory() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- 
Deprecated. Returns the factory by which this context was created. 
- getContextName() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- 
Deprecated. Returns the context name. 
- getCost(ProcessingDetails) - Method in interface org.apache.hadoop.ipc.CostProvider
- 
Get cost from ProcessingDetailswhich will be used in scheduler.
 
- getCost(ProcessingDetails) - Method in class org.apache.hadoop.ipc.DefaultCostProvider
- 
Returns 1, regardless of the processing details. 
- getCost(ProcessingDetails) - Method in class org.apache.hadoop.ipc.WeightedTimeCostProvider
- 
Calculates a weighted sum of the times stored on the provided processing
 details to be used as the cost in  DecayRpcScheduler. 
- getCount() - Method in interface org.apache.hadoop.log.LogThrottlingHelper.LogAction
- 
Return the number of records encapsulated in this action; that is, the
 number of times recordwas called to produce this action,
 including the current one.
 
- getCount() - Method in interface org.apache.hadoop.metrics2.util.QuantileEstimator
-  
- getCount() - Method in class org.apache.hadoop.record.Buffer
- 
Deprecated. Get the current count of the buffer. 
- getCpuFrequency() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the CPU frequency of on the system. 
- getCpuUsagePercentage() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the CPU usage % of the machine. 
- getCrcType() - Method in class org.apache.hadoop.fs.MD5MD5CRC32CastagnoliFileChecksum
-  
- getCrcType() - Method in class org.apache.hadoop.fs.MD5MD5CRC32GzipFileChecksum
-  
- getCreated() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Metadata
-  
- getCreationFallbacks() - Method in interface org.apache.hadoop.fs.BlockStoragePolicySpi
- 
Get the fallback storage types for creating new block replicas. 
- getCredential() - Method in class org.apache.hadoop.security.alias.CredentialProvider.CredentialEntry
-  
- getCredentialEntry(String) - Method in class org.apache.hadoop.security.alias.CredentialProvider
- 
Get the credential entry for a specific alias. 
- getCredentials() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Obtain the tokens in credentials form associated with this user. 
- getCumulativeCpuTime() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the cumulative CPU time since the system is on. 
- getCurCall() - Static method in class org.apache.hadoop.ipc.Server
- 
Get the current call 
- getCurrentKey(String) - Method in class org.apache.hadoop.crypto.key.CachingKeyProvider
-  
- getCurrentKey(String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Get the current version of the key, which should be used for encrypting new
 data. 
- getCurrentKey(String) - Method in class org.apache.hadoop.crypto.key.KeyProviderExtension
-  
- getCurrentKey(String) - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- getCurrentKeyId() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
- 
For subclasses externalizing the storage, for example Zookeeper
 based implementations 
- getCurrentTrashDir(Path) - Method in class org.apache.hadoop.fs.Trash
-  
- getCurrentTrashDir() - Method in class org.apache.hadoop.fs.TrashPolicy
- 
Get the current working directory of the Trash Policy
 This API does not work with files deleted from encryption zone when HDFS
 data encryption at rest feature is enabled as rename file between
 encryption zones or encryption zone and non-encryption zone is not allowed. 
- getCurrentTrashDir(Path) - Method in class org.apache.hadoop.fs.TrashPolicy
- 
Get the current trash directory for path specified based on the Trash
 Policy 
- getCurrentUser() - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Return the current user, including any doAs in the current stack. 
- getCurrentValue(Writable) - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Get the 'value' corresponding to the last read 'key'. 
- getCurrentValue(Object) - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Get the 'value' corresponding to the last read 'key'. 
- getCustomMessage() - Method in class org.apache.hadoop.conf.Configuration.DeprecationDelta
-  
- getData() - Method in class org.apache.hadoop.fs.FileSystem.Statistics
- 
Get all statistics data. 
- getData() - Method in class org.apache.hadoop.io.DataInputByteBuffer
-  
- getData() - Method in class org.apache.hadoop.io.DataOutputByteBuffer
-  
- getDate() - Static method in class org.apache.hadoop.util.VersionInfo
- 
The date that Hadoop was compiled. 
- getDeclaredClass() - Method in class org.apache.hadoop.io.ObjectWritable
- 
Return the class this is meant to be. 
- getDeclaredComponentType() - Method in class org.apache.hadoop.io.ArrayPrimitiveWritable
-  
- getDeclaredFieldsIncludingInherited(Class<?>) - Static method in class org.apache.hadoop.util.ReflectionUtils
- 
Gets all the declared fields of a class including fields declared in
 superclasses. 
- getDeclaredMethodsIncludingInherited(Class<?>) - Static method in class org.apache.hadoop.util.ReflectionUtils
- 
Gets all the declared methods of a class including methods declared in
 superclasses. 
- getDeclaringClassProtocolName() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required string declaringClassProtocolName = 2;
 
- getDeclaringClassProtocolName() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
- 
required string declaringClassProtocolName = 2;
 
- getDeclaringClassProtocolName() - Method in interface org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProtoOrBuilder
- 
required string declaringClassProtocolName = 2;
 
- getDeclaringClassProtocolNameBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required string declaringClassProtocolName = 2;
 
- getDeclaringClassProtocolNameBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
- 
required string declaringClassProtocolName = 2;
 
- getDeclaringClassProtocolNameBytes() - Method in interface org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProtoOrBuilder
- 
required string declaringClassProtocolName = 2;
 
- getDecompressionBufferSize(Configuration) - Static method in class org.apache.hadoop.io.compress.ZStandardCodec
-  
- getDecompressor(CompressionCodec) - Static method in class org.apache.hadoop.io.compress.CodecPool
- 
- getDecompressor() - Method in enum org.apache.hadoop.io.file.tfile.Compression.Algorithm
-  
- getDecompressorType() - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
- getDecompressorType() - Method in interface org.apache.hadoop.io.compress.CompressionCodec
- 
- getDecompressorType() - Method in class org.apache.hadoop.io.compress.DefaultCodec
-  
- getDecompressorType() - Method in class org.apache.hadoop.io.compress.GzipCodec
-  
- getDecompressorType() - Method in class org.apache.hadoop.io.compress.Lz4Codec
- 
- getDecompressorType() - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
- getDecompressorType() - Method in class org.apache.hadoop.io.compress.ZStandardCodec
- 
- getDefault() - Static method in class org.apache.hadoop.fs.permission.FsPermission
- 
Get the default permission for directory and symlink. 
- getDefaultBlockSize() - Method in class org.apache.hadoop.fs.FileSystem
- 
- getDefaultBlockSize(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Return the number of bytes that large input files should be optimally
 be split into to minimize I/O time. 
- getDefaultBlockSize() - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getDefaultBlockSize(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getDefaultBlockSize() - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getDefaultBlockSize(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getDefaultBlockSize() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getDefaultBlockSize(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getDefaultCompressionType(Configuration) - Static method in class org.apache.hadoop.io.SequenceFile
- 
Get the compression type for the reduce outputs 
- getDefaultDelegationTokenAuthenticator() - Static method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
- 
- getDefaultExtension() - Method in class org.apache.hadoop.io.compress.BZip2Codec
- 
.bz2 is recognized as the default extension for compressed BZip2 files 
- getDefaultExtension() - Method in interface org.apache.hadoop.io.compress.CompressionCodec
- 
Get the default filename extension for this kind of compression. 
- getDefaultExtension() - Method in class org.apache.hadoop.io.compress.DefaultCodec
-  
- getDefaultExtension() - Method in class org.apache.hadoop.io.compress.GzipCodec
-  
- getDefaultExtension() - Method in class org.apache.hadoop.io.compress.Lz4Codec
- 
Get the default filename extension for this kind of compression. 
- getDefaultExtension() - Method in class org.apache.hadoop.io.compress.SnappyCodec
- 
Get the default filename extension for this kind of compression. 
- getDefaultExtension() - Method in class org.apache.hadoop.io.compress.ZStandardCodec
- 
Get the default filename extension for this kind of compression. 
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto
-  
- getDefaultInstance() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
-  
- getDefaultInstanceForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
-  
- getDefaultPort() - Method in class org.apache.hadoop.fs.FileSystem
- 
Get the default port for this FileSystem. 
- getDefaultPort() - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
- 
Get the default port for this FTPFileSystem. 
- getDefaultProperties() - Method in class org.apache.hadoop.security.SaslPropertiesResolver
- 
The default Sasl Properties read from the configuration 
- getDefaultReplication() - Method in class org.apache.hadoop.fs.FileSystem
- 
- getDefaultReplication(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Get the default replication for a path. 
- getDefaultReplication() - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getDefaultReplication(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getDefaultReplication() - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getDefaultReplication(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getDefaultReplication() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getDefaultReplication(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getDefaultRetryPolicy(Configuration, String, boolean, String, String, String) - Static method in class org.apache.hadoop.io.retry.RetryUtils
- 
Return the default retry policy set in conf. 
- getDefaultStoragePolicyId() - Method in class org.apache.hadoop.fs.FsServerDefaults
-  
- getDefaultUri(Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
- 
Get the default FileSystem URI from a configuration. 
- getDelay(TimeUnit) - Method in class org.apache.hadoop.fs.DelegationTokenRenewer.RenewAction
- 
Get the delay until this event should happen. 
- getDelegationKey(int) - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
- 
For subclasses externalizing the storage, for example Zookeeper
 based implementations 
- getDelegationToken(URL, DelegationTokenAuthenticatedURL.Token, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
- 
Requests a delegation token using the configured Authenticatorfor authentication.
 
- getDelegationToken(URL, DelegationTokenAuthenticatedURL.Token, String, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
- 
Requests a delegation token using the configured Authenticatorfor authentication.
 
- getDelegationToken() - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL.Token
-  
- getDelegationToken(URL, AuthenticatedURL.Token, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
- 
Requests a delegation token using the configured Authenticatorfor authentication.
 
- getDelegationToken(URL, AuthenticatedURL.Token, String, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
- 
Requests a delegation token using the configured Authenticatorfor authentication.
 
- getDelegationTokens(String) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getDelegationTokenSeqNum() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
- 
For subclasses externalizing the storage, for example Zookeeper
 based implementations 
- getDescription() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Metadata
-  
- getDescription() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Options
-  
- getDescriptions(int) - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptions(int) - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptions(int) - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProtoOrBuilder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsBuilder(int) - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsBuilderList() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsCount() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsCount() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsCount() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProtoOrBuilder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsList() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsList() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsList() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProtoOrBuilder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsOrBuilder(int) - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsOrBuilder(int) - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsOrBuilder(int) - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProtoOrBuilder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsOrBuilderList() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsOrBuilderList() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptionsOrBuilderList() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProtoOrBuilder
- 
repeated .hadoop.common.SpanReceiverListInfo descriptions = 1;
 
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
-  
- getDescriptor() - Static method in enum org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HARequestSource
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService
-  
- getDescriptor() - Static method in enum org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceStateProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshProtocolService
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueProtocolService
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
-  
- getDescriptor() - Static method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcKindProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
-  
- getDescriptor() - Static method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.OperationProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
-  
- getDescriptor() - Static method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.RpcErrorCodeProto
-  
- getDescriptor() - Static method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.RpcStatusProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
-  
- getDescriptor() - Static method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslState
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshAuthorizationPolicyProtocolService
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserMappingsProtocolService
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos
-  
- getDescriptor() - Static method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
-  
- getDescriptor() - Static method in class org.apache.hadoop.tracing.TraceAdminPB.TraceAdminService
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
-  
- getDescriptorForType() - Method in enum org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HARequestSource
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService
-  
- getDescriptorForType() - Method in enum org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceStateProto
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshProtocolService
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueProtocolService
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
-  
- getDescriptorForType() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcKindProto
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
-  
- getDescriptorForType() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.OperationProto
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
-  
- getDescriptorForType() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.RpcErrorCodeProto
-  
- getDescriptorForType() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.RpcStatusProto
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
-  
- getDescriptorForType() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslState
-  
- getDescriptorForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshAuthorizationPolicyProtocolService
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserMappingsProtocolService
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
-  
- getDescriptorForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.TraceAdminService
-  
- getDetailedMetricsName() - Method in class org.apache.hadoop.ipc.ExternalCall
-  
- getDigest() - Method in class org.apache.hadoop.io.MD5Hash
- 
Returns the digest bytes. 
- getDigester() - Static method in class org.apache.hadoop.io.MD5Hash
- 
Create a thread local MD5 digester 
- getDirDefault() - Static method in class org.apache.hadoop.fs.permission.FsPermission
- 
Get the default permission for directory. 
- getDirectoryCount() - Method in class org.apache.hadoop.fs.ContentSummary
-  
- getDmax(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
- 
Deprecated. 
- getDNSSubjectAlts(X509Certificate) - Static method in class org.apache.hadoop.security.ssl.SSLHostnameVerifier.Certificates
- 
Extracts the array of SubjectAlt DNS names from an X509Certificate. 
- getDouble(String, double) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as adouble.
 
- getDU(File) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Takes an input dir and returns the du on that local directory. 
- getEffectivePermission(AclEntry) - Method in class org.apache.hadoop.fs.permission.AclStatus
- 
Get the effective permission for the AclEntry 
- getEffectivePermission(AclEntry, FsPermission) - Method in class org.apache.hadoop.fs.permission.AclStatus
- 
Get the effective permission for the AclEntry. 
- getEffectiveUser() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
- 
optional string effectiveUser = 1;
 
- getEffectiveUser() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
- 
optional string effectiveUser = 1;
 
- getEffectiveUser() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProtoOrBuilder
- 
optional string effectiveUser = 1;
 
- getEffectiveUserBytes() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
- 
optional string effectiveUser = 1;
 
- getEffectiveUserBytes() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
- 
optional string effectiveUser = 1;
 
- getEffectiveUserBytes() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProtoOrBuilder
- 
optional string effectiveUser = 1;
 
- getElementType() - Method in class org.apache.hadoop.io.EnumSetWritable
- 
Returns the class of all the elements of the underlying EnumSetWriable. 
- getElementTypeID() - Method in class org.apache.hadoop.record.meta.VectorTypeID
- 
Deprecated. 
- getEmptier() - Method in class org.apache.hadoop.fs.Trash
- 
Return a  Runnable that periodically empties the trash of all
 users, intended to be run by the superuser. 
- getEmptier() - Method in class org.apache.hadoop.fs.TrashPolicy
- 
Return a  Runnable that periodically empties the trash of all
 users, intended to be run by the superuser. 
- getEmptierInterval() - Method in class org.apache.hadoop.fs.TrashPolicyDefault.Emptier
-  
- getEnabledConfigKey() - Method in class org.apache.hadoop.security.HttpCrossOriginFilterInitializer
-  
- getEncoded() - Method in class org.apache.hadoop.crypto.key.JavaKeyStoreProvider.KeyMetadata
-  
- getEncryptDataTransfer() - Method in class org.apache.hadoop.fs.FsServerDefaults
-  
- getEncryptedBit() - Method in class org.apache.hadoop.fs.permission.FsPermission
- 
Returns true if the file is encrypted or directory is in an encryption zone 
- getEncryptedKeyIv() - Method in class org.apache.hadoop.crypto.key.KeyProviderCryptoExtension.EncryptedKeyVersion
-  
- getEncryptedKeyVersion() - Method in class org.apache.hadoop.crypto.key.KeyProviderCryptoExtension.EncryptedKeyVersion
-  
- getEncryptionKeyName() - Method in class org.apache.hadoop.crypto.key.KeyProviderCryptoExtension.EncryptedKeyVersion
-  
- getEncryptionKeyVersionName() - Method in class org.apache.hadoop.crypto.key.KeyProviderCryptoExtension.EncryptedKeyVersion
-  
- getEndColumn() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
- 
Deprecated. 
- getEndLine() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
- 
Deprecated. 
- getEndTime() - Method in class org.apache.hadoop.conf.ReconfigurationTaskStatus
-  
- getEntries() - Method in class org.apache.hadoop.fs.permission.AclStatus
- 
Returns the list of all ACL entries, ordered by their natural ordering. 
- getEntryComparator() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get a Comparator object to compare Entries. 
- getEntryCount() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get the number of key-value pair entries in TFile. 
- getEnum(String, T) - Method in class org.apache.hadoop.conf.Configuration
- 
Return value matching this enumerated type. 
- getEnvironment(String) - Method in class org.apache.hadoop.util.Shell
- 
Get an environment variable. 
- getEnvironmentVariableRegex() - Static method in class org.apache.hadoop.util.Shell
- 
Return a regular expression string that match environment variables. 
- getErr() - Method in class org.apache.hadoop.fs.shell.find.FindOptions
- 
Returns the error stream to be used. 
- getErrno() - Method in exception org.apache.hadoop.io.nativeio.NativeIOException
-  
- getErrorCode() - Method in exception org.apache.hadoop.io.nativeio.NativeIOException
-  
- getErrorCode() - Method in exception org.apache.hadoop.ipc.RemoteException
-  
- getErrorDetail() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional .hadoop.common.RpcResponseHeaderProto.RpcErrorCodeProto errorDetail = 6;
 
- getErrorDetail() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional .hadoop.common.RpcResponseHeaderProto.RpcErrorCodeProto errorDetail = 6;
 
- getErrorDetail() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional .hadoop.common.RpcResponseHeaderProto.RpcErrorCodeProto errorDetail = 6;
 
- getErrorMsg() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional string errorMsg = 5;
 
- getErrorMsg() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional string errorMsg = 5;
 
- getErrorMsg() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional string errorMsg = 5;
 
- getErrorMsgBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional string errorMsg = 5;
 
- getErrorMsgBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional string errorMsg = 5;
 
- getErrorMsgBytes() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional string errorMsg = 5;
 
- getEstablishedQOP() - Method in class org.apache.hadoop.ipc.Server.Connection
-  
- getEstimator() - Method in class org.apache.hadoop.metrics2.lib.MutableQuantiles
- 
Get the quantile estimator. 
- getExceptionClassName() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional string exceptionClassName = 4;
 
- getExceptionClassName() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional string exceptionClassName = 4;
 
- getExceptionClassName() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional string exceptionClassName = 4;
 
- getExceptionClassNameBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional string exceptionClassName = 4;
 
- getExceptionClassNameBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional string exceptionClassName = 4;
 
- getExceptionClassNameBytes() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional string exceptionClassName = 4;
 
- getExceptions() - Method in exception org.apache.hadoop.io.MultipleIOException
-  
- getExceptions() - Method in exception org.apache.hadoop.io.retry.MultiException
-  
- getExcludedHosts() - Method in class org.apache.hadoop.util.HostsFileReader.HostDetails
-  
- getExcludesFile() - Method in class org.apache.hadoop.util.HostsFileReader.HostDetails
-  
- getExecString() - Method in class org.apache.hadoop.util.Shell
- 
return an array containing the command name and its parameters. 
- getExecString() - Method in class org.apache.hadoop.util.Shell.ShellCommandExecutor
-  
- getExitCode() - Method in exception org.apache.hadoop.service.ServiceStateException
-  
- getExitCode() - Method in interface org.apache.hadoop.util.ExitCodeProvider
- 
Method to get the exit code. 
- getExitCode() - Method in exception org.apache.hadoop.util.ExitUtil.ExitException
-  
- getExitCode() - Method in exception org.apache.hadoop.util.ExitUtil.HaltException
-  
- getExitCode() - Method in interface org.apache.hadoop.util.Shell.CommandExecutor
-  
- getExitCode() - Method in exception org.apache.hadoop.util.Shell.ExitCodeException
-  
- getExitCode() - Method in class org.apache.hadoop.util.Shell
- 
get the exit code. 
- getExitStatus() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional int32 exitStatus = 1;
 
- getExitStatus() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
- 
optional int32 exitStatus = 1;
 
- getExitStatus() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProtoOrBuilder
- 
optional int32 exitStatus = 1;
 
- getExpirationTime() - Method in class org.apache.hadoop.ipc.RetryCache.CacheEntry
-  
- getExpirationTime() - Method in interface org.apache.hadoop.util.LightWeightCache.Entry
- 
Get the expiration time. 
- getExtension() - Method in class org.apache.hadoop.crypto.key.KeyProviderExtension
-  
- getFactor() - Method in class org.apache.hadoop.io.SequenceFile.Sorter
- 
Get the number of streams to merge at once. 
- getFactory(Class) - Static method in class org.apache.hadoop.io.WritableFactories
- 
Define a factory for a class. 
- getFailureCause() - Method in class org.apache.hadoop.service.AbstractService
-  
- getFailureCause() - Method in interface org.apache.hadoop.service.Service
- 
Get the first exception raised during the service failure. 
- getFailureState() - Method in class org.apache.hadoop.service.AbstractService
-  
- getFailureState() - Method in interface org.apache.hadoop.service.Service
- 
- getFencer() - Method in class org.apache.hadoop.ha.HAServiceTarget
-  
- getFencingParameters() - Method in class org.apache.hadoop.ha.HAServiceTarget
-  
- getFieldID() - Method in class org.apache.hadoop.record.meta.FieldTypeInfo
- 
Deprecated. get the field's id (name) 
- getFieldTypeInfos() - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
- 
Deprecated. Return a collection of field type infos 
- getFieldTypeInfos() - Method in class org.apache.hadoop.record.meta.StructTypeID
- 
Deprecated. 
- getFile(String, String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get a local file name under a directory named in dirsProp with
 the given path. 
- getFileAndDirectoryCount() - Method in class org.apache.hadoop.fs.QuotaUsage
- 
Return the directory count. 
- getFileBlockLocations(Path, long, long) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.fs.FileSystem
- 
Return an array containing hostnames, offset and size of
 portions of the given file. 
- getFileBlockLocations(Path, long, long) - Method in class org.apache.hadoop.fs.FileSystem
- 
Return an array containing hostnames, offset and size of
 portions of the given file. 
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.fs.HarFileSystem
- 
Get block locations from the underlying fs and fix their
 offsets and lengths. 
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getFileBlockLocations(Path, long, long) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getFileBufferSize() - Method in class org.apache.hadoop.fs.FsServerDefaults
-  
- getFileChecksum(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
- getFileChecksum(Path) - Method in class org.apache.hadoop.fs.FileContext
- 
Get the checksum of a file. 
- getFileChecksum(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Get the checksum of a file, if the FS supports checksums. 
- getFileChecksum(Path, long) - Method in class org.apache.hadoop.fs.FileSystem
- 
Get the checksum of a file, from the beginning of the file till the
 specific length. 
- getFileChecksum(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getFileChecksum(Path, long) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getFileChecksum(Path, long) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getFileChecksum(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getFileChecksum(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getFileContext(AbstractFileSystem, Configuration) - Static method in class org.apache.hadoop.fs.FileContext
- 
Create a FileContext with specified FS as default using the specified
 config. 
- getFileContext(AbstractFileSystem) - Static method in class org.apache.hadoop.fs.FileContext
- 
Create a FileContext for specified file system using the default config. 
- getFileContext() - Static method in class org.apache.hadoop.fs.FileContext
- 
Create a FileContext using the default config read from the
 $HADOOP_CONFIG/core.xml, Unspecified key-values for config are defaulted
 from core-defaults.xml in the release jar. 
- getFileContext(URI) - Static method in class org.apache.hadoop.fs.FileContext
- 
Create a FileContext for specified URI using the default config. 
- getFileContext(URI, Configuration) - Static method in class org.apache.hadoop.fs.FileContext
- 
Create a FileContext for specified default URI using the specified config. 
- getFileContext(Configuration) - Static method in class org.apache.hadoop.fs.FileContext
- 
Create a FileContext using the passed config. 
- getFileCount() - Method in class org.apache.hadoop.fs.ContentSummary
-  
- getFileCount() - Method in class org.apache.hadoop.fs.DUHelper
-  
- getFileDefault() - Static method in class org.apache.hadoop.fs.permission.FsPermission
- 
Get the default permission for file. 
- getFileDescriptor() - Method in class org.apache.hadoop.fs.FSDataInputStream
-  
- getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
The specification of this method matches that of
  FileContext.getFileLinkStatus(Path)
 except that an UnresolvedLinkException may be thrown if a symlink is  
 encountered in the path leading up to the final path component. 
- getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.FileContext
- 
Return a file status object that represents the path. 
- getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
- getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.LocalFileSystem
-  
- getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
- 
Return a FileStatus representing the given path. 
- getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getFilename() - Method in class org.apache.hadoop.http.HttpRequestLogAppender
-  
- getFileStatus(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
The specification of this method matches that of
  FileContext.getFileStatus(Path) 
 except that an UnresolvedLinkException may be thrown if a symlink is 
 encountered in the path. 
- getFileStatus(Path) - Method in class org.apache.hadoop.fs.FileContext
- 
Return a file status object that represents the path. 
- getFileStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Return a file status object that represents the path. 
- getFileStatus(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
Get file status. 
- getFileStatus(Path) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
-  
- getFileStatus(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
- 
return the filestatus of files in har archive. 
- getFileStatus(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- getFileStatus(Path) - Method in class org.apache.hadoop.fs.sftp.SFTPFileSystem
-  
- getFileStatus(PathData, int) - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
- 
- getFileStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getFileStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getFileSystem(Configuration) - Method in class org.apache.hadoop.fs.Path
- 
Return the FileSystem that owns this Path. 
- getFileSystem(PathData) - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
- 
Returns the  FileSystem associated with the  PathData item. 
- getFileSystemClass(String, Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
- 
Get the FileSystem implementation class of a filesystem. 
- getFilterConfigMap(Configuration, String) - Static method in class org.apache.hadoop.security.AuthenticationFilterInitializer
-  
- getFilterParameters(Configuration, String) - Static method in class org.apache.hadoop.security.HttpCrossOriginFilterInitializer
-  
- getFilterParams(Configuration, String) - Static method in class org.apache.hadoop.security.http.RestCsrfPreventionFilter
- 
Constructs a mapping of configuration properties to be used for filter
 initialization. 
- getFilterParams(Configuration, String) - Static method in class org.apache.hadoop.security.http.XFrameOptionsFilter
- 
Constructs a mapping of configuration properties to be used for filter
 initialization. 
- getFinalParameters() - Method in class org.apache.hadoop.conf.Configuration
- 
Get the set of parameters marked final. 
- getFirstKey() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get the first key in the TFile. 
- getFlags() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
-  
- getFloat(String, float) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as afloat.
 
- getFolderUsage(String) - Static method in class org.apache.hadoop.fs.DUHelper
-  
- getFormat() - Method in class org.apache.hadoop.crypto.key.JavaKeyStoreProvider.KeyMetadata
-  
- getFS() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
-  
- getFsAction(String) - Static method in enum org.apache.hadoop.fs.permission.FsAction
- 
Get the FsAction enum for String representation of permissions 
- getFSofPath(Path) - Method in class org.apache.hadoop.fs.FileContext
- 
Get the file system of supplied path. 
- getFSofPath(Path, Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
-  
- getFsStatus(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
- getFsStatus() - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
- getFsStatus(Path) - Method in class org.apache.hadoop.fs.FileContext
- 
Returns a status object describing the use and capacity of the
 file system denoted by the Parh argument p. 
- getFsStatus() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getFstat(FileDescriptor) - Static method in class org.apache.hadoop.io.nativeio.NativeIO.POSIX
- 
Returns the file stat for a file descriptor. 
- getGangliaConfForMetric(String) - Method in class org.apache.hadoop.metrics2.sink.ganglia.AbstractGangliaSink
- 
Lookup GangliaConf from cache. 
- getGcMonitorRunTime() - Method in class org.apache.hadoop.util.GcTimeMonitor.GcData
- 
Returns the time since the start of the associated GcTimeMonitor. 
- getGcTimePercentage() - Method in class org.apache.hadoop.util.GcTimeMonitor.GcData
- 
Returns the percentage (0..100) of time that the JVM spent in GC pauses
 within the observation window of the associated GcTimeMonitor. 
- getGetPermissionCommand() - Static method in class org.apache.hadoop.util.Shell
- 
Return a command to get permission information. 
- getGid(String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
-  
- getGid(String) - Method in class org.apache.hadoop.security.ShellBasedIdMapping
-  
- getGidAllowingUnknown(String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
-  
- getGidAllowingUnknown(String) - Method in class org.apache.hadoop.security.ShellBasedIdMapping
-  
- getGidNameMap() - Method in class org.apache.hadoop.security.ShellBasedIdMapping
-  
- getGlobalStorageStatistics() - Static method in class org.apache.hadoop.fs.FileSystem
- 
Get the global storage statistics. 
- getGroup() - Method in class org.apache.hadoop.fs.FileStatus
- 
Get the group associated with the file. 
- getGroup() - Method in class org.apache.hadoop.fs.permission.AclStatus
- 
Returns the file group. 
- getGroup() - Method in class org.apache.hadoop.io.nativeio.NativeIO.POSIX.Stat
-  
- getGroupAction() - Method in class org.apache.hadoop.fs.permission.FsPermission
- 
- getGroupName(int, String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
-  
- getGroupName(int, String) - Method in class org.apache.hadoop.security.ShellBasedIdMapping
-  
- getGroupNames() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Get the group names for this user. 
- getGroups() - Method in class org.apache.hadoop.security.authorize.AccessControlList
- 
Get the names of user groups allowed for this service. 
- getGroups(String) - Method in interface org.apache.hadoop.security.GroupMappingServiceProvider
- 
Get all various group memberships of a given user. 
- getGroups(String) - Method in class org.apache.hadoop.security.JniBasedUnixGroupsMappingWithFallback
-  
- getGroups(String) - Method in class org.apache.hadoop.security.JniBasedUnixGroupsNetgroupMappingWithFallback
-  
- getGroups(String) - Method in class org.apache.hadoop.security.NullGroupsMapping
- 
Returns an empty list. 
- getGroups() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Get the group names for this user. 
- getGroups(int) - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder
- 
repeated string groups = 1;
 
- getGroups(int) - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
- 
repeated string groups = 1;
 
- getGroups(int) - Method in interface org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProtoOrBuilder
- 
repeated string groups = 1;
 
- GetGroupsBase - Class in org.apache.hadoop.tools
- 
Base class for the HDFS and MR implementations of tools which fetch and
 display the groups that users belong to. 
- GetGroupsBase(Configuration) - Constructor for class org.apache.hadoop.tools.GetGroupsBase
- 
Create an instance of this tool using the given configuration. 
- GetGroupsBase(Configuration, PrintStream) - Constructor for class org.apache.hadoop.tools.GetGroupsBase
- 
Used exclusively for testing. 
- getGroupsBytes(int) - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder
- 
repeated string groups = 1;
 
- getGroupsBytes(int) - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
- 
repeated string groups = 1;
 
- getGroupsBytes(int) - Method in interface org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProtoOrBuilder
- 
repeated string groups = 1;
 
- getGroupsCommand() - Static method in class org.apache.hadoop.util.Shell
- 
a Unix command to get the current user's groups list. 
- getGroupsCount() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder
- 
repeated string groups = 1;
 
- getGroupsCount() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
- 
repeated string groups = 1;
 
- getGroupsCount() - Method in interface org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProtoOrBuilder
- 
repeated string groups = 1;
 
- getGroupsForUser(RpcController, GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto) - Method in interface org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService.BlockingInterface
-  
- getGroupsForUser(RpcController, GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto, RpcCallback<GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto>) - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService
- 
rpc getGroupsForUser(.hadoop.common.GetGroupsForUserRequestProto) returns (.hadoop.common.GetGroupsForUserResponseProto);
 
- getGroupsForUser(RpcController, GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto, RpcCallback<GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto>) - Method in interface org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService.Interface
- 
rpc getGroupsForUser(.hadoop.common.GetGroupsForUserRequestProto) returns (.hadoop.common.GetGroupsForUserResponseProto);
 
- getGroupsForUser(RpcController, GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto, RpcCallback<GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto>) - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService.Stub
-  
- getGroupsForUser(String) - Method in class org.apache.hadoop.tools.protocolPB.GetUserMappingsProtocolClientSideTranslatorPB
-  
- getGroupsForUser(RpcController, GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto) - Method in class org.apache.hadoop.tools.protocolPB.GetUserMappingsProtocolServerSideTranslatorPB
-  
- getGroupsForUserCommand(String) - Static method in class org.apache.hadoop.util.Shell
- 
A command to get a given user's groups list. 
- getGroupsIDForUserCommand(String) - Static method in class org.apache.hadoop.util.Shell
- 
A command to get a given user's group id list. 
- getGroupsList() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder
- 
repeated string groups = 1;
 
- getGroupsList() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
- 
repeated string groups = 1;
 
- getGroupsList() - Method in interface org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProtoOrBuilder
- 
repeated string groups = 1;
 
- getHadoopHome() - Static method in class org.apache.hadoop.util.Shell
- 
Get the Hadoop home directory. 
- getHarHash(Path) - Static method in class org.apache.hadoop.fs.HarFileSystem
- 
the hash of the path p inside  the filesystem 
- getHarVersion() - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getHeader(boolean) - Static method in class org.apache.hadoop.fs.ContentSummary
- 
Return the header of the output. 
- getHeader() - Static method in class org.apache.hadoop.fs.QuotaUsage
- 
Return the header of the output. 
- getHeader(String) - Method in interface org.apache.hadoop.security.http.RestCsrfPreventionFilter.HttpInteraction
- 
Returns the value of a header. 
- getHeaderFields() - Static method in class org.apache.hadoop.fs.ContentSummary
- 
Returns the names of the fields from the summary header. 
- getHealthMonitorAddress() - Method in class org.apache.hadoop.ha.HAServiceTarget
- 
Returns an optional separate RPC server address for health checks at the
 target node. 
- getHealthMonitorProxy(Configuration, int) - Method in class org.apache.hadoop.ha.HAServiceTarget
- 
Returns a proxy to connect to the target HA service for health monitoring. 
- getHealthReport() - Method in class org.apache.hadoop.util.NodeHealthScriptRunner
- 
Returns output from health script. 
- getHelp() - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
-  
- getHelp() - Method in interface org.apache.hadoop.fs.shell.find.Expression
- 
Returns a description of the expression for use in help. 
- getHelp() - Method in class org.apache.hadoop.fs.shell.find.FilterExpression
-  
- getHomeDirectory() - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Return the current user's home directory in this file system. 
- getHomeDirectory() - Method in class org.apache.hadoop.fs.FileContext
- 
Return the current user's home directory in this file system. 
- getHomeDirectory() - Method in class org.apache.hadoop.fs.FileSystem
- 
Return the current user's home directory in this FileSystem. 
- getHomeDirectory() - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getHomeDirectory() - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
-  
- getHomeDirectory() - Method in class org.apache.hadoop.fs.HarFileSystem
- 
return the top level archive path. 
- getHomeDirectory() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- getHomeDirectory() - Method in class org.apache.hadoop.fs.sftp.SFTPFileSystem
-  
- getHomeDirectory() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getHomeDirectory() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getHomeDirValue(Configuration) - Static method in class org.apache.hadoop.fs.viewfs.ConfigUtil
- 
Get the value of the home dir conf value for default mount table 
- getHomeDirValue(Configuration, String) - Static method in class org.apache.hadoop.fs.viewfs.ConfigUtil
- 
Get the value of the home dir conf value for specfied mount table 
- getHostAddress() - Method in class org.apache.hadoop.ipc.Server.Call
-  
- getHostAddress() - Method in class org.apache.hadoop.ipc.Server.Connection
-  
- getHostFromPrincipal(String) - Static method in class org.apache.hadoop.security.SecurityUtil
- 
Get the host name from the principal name of format /host@realm. 
- getHostInetAddress() - Method in class org.apache.hadoop.ipc.Server.Call
-  
- getHostInetAddress() - Method in class org.apache.hadoop.ipc.Server.Connection
-  
- getHostName() - Method in class org.apache.hadoop.metrics2.sink.ganglia.AbstractGangliaSink
-  
- getHosts() - Method in class org.apache.hadoop.fs.BlockLocation
- 
Get the list of hosts (hostname) hosting this block 
- getId(Class<?>) - Method in class org.apache.hadoop.io.AbstractMapWritable
-  
- getId() - Method in class org.apache.hadoop.tracing.SpanReceiverInfo
-  
- getId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto.Builder
- 
required int64 id = 1;
 
- getId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto
- 
required int64 id = 1;
 
- getId() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProtoOrBuilder
- 
required int64 id = 1;
 
- getId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto.Builder
- 
required int64 id = 1;
 
- getId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto
- 
required int64 id = 1;
 
- getId() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProtoOrBuilder
- 
required int64 id = 1;
 
- getId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
- 
required int64 id = 1;
 
- getId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
- 
required int64 id = 1;
 
- getId() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfoOrBuilder
- 
required int64 id = 1;
 
- getIdentifier() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
- 
optional string identifier = 1;
 
- getIdentifier() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
- 
optional string identifier = 1;
 
- getIdentifier() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProtoOrBuilder
- 
optional string identifier = 1;
 
- getIdentifier() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required bytes identifier = 1;
 
- getIdentifier() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
- 
required bytes identifier = 1;
 
- getIdentifier() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.TokenProtoOrBuilder
- 
required bytes identifier = 1;
 
- getIdentifier() - Method in class org.apache.hadoop.security.token.Token
- 
Get the token identifier's byte representation 
- getIdentifierBytes() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
- 
optional string identifier = 1;
 
- getIdentifierBytes() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
- 
optional string identifier = 1;
 
- getIdentifierBytes() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProtoOrBuilder
- 
optional string identifier = 1;
 
- GetImage() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
- 
Deprecated. 
- getIn() - Method in class org.apache.hadoop.fs.shell.find.FindOptions
- 
Returns the input stream to be used. 
- getIncludedHosts() - Method in class org.apache.hadoop.util.HostsFileReader.HostDetails
-  
- getIncludesFile() - Method in class org.apache.hadoop.util.HostsFileReader.HostDetails
-  
- getIndexInterval() - Method in class org.apache.hadoop.io.MapFile.Writer
- 
The number of entries that are added before an index entry is added. 
- getIngressPort() - Method in class org.apache.hadoop.ipc.Server.Connection
-  
- getInitialMessage() - Method in exception org.apache.hadoop.security.KerberosAuthException
-  
- getInitialUsed() - Method in class org.apache.hadoop.fs.GetSpaceUsed.Builder
-  
- getInitialWorkingDirectory() - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Some file systems like LocalFileSystem have an initial workingDir
 that is used as the starting workingDir. 
- getInitialWorkingDirectory() - Method in class org.apache.hadoop.fs.FileSystem
- 
Note: with the new FileContext class, getWorkingDirectory()
 will be removed. 
- getInitialWorkingDirectory() - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getInitialWorkingDirectory() - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getInitialWorkingDirectory() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- getInstance(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.fs.TrashPolicy
- 
- getInstance(Configuration, FileSystem) - Static method in class org.apache.hadoop.fs.TrashPolicy
- 
Get an instance of the configured TrashPolicy based on the value
 of the configuration parameter fs.trash.classname. 
- getInstance(String, int, DecayRpcScheduler) - Static method in class org.apache.hadoop.ipc.DecayRpcScheduler.MetricsProxy
-  
- getInstance(Configuration) - Static method in class org.apache.hadoop.security.SaslPropertiesResolver
- 
Returns an instance of SaslPropertiesResolver. 
- getInstances(String, Class<U>) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as aListof objects implementing the interface specified byxface.
 
- getInt(String, int) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as anint.
 
- getInterface() - Method in class org.apache.hadoop.io.retry.DefaultFailoverProxyProvider
-  
- getInterface() - Method in interface org.apache.hadoop.io.retry.FailoverProxyProvider
- 
Return a reference to the interface this provider's proxy objects actually
 implement. 
- getInterfaceName() - Method in exception org.apache.hadoop.ipc.RPC.VersionMismatch
- 
Get the interface name 
- getInterval() - Method in class org.apache.hadoop.fs.GetSpaceUsed.Builder
-  
- getInterval() - Method in class org.apache.hadoop.metrics2.lib.MutableQuantiles
-  
- getInts(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as a set of comma-delimitedintvalues.
 
- getIssueDate() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenIdentifier
-  
- getJarsInDirectory(String) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Returns all jars that are in the directory. 
- getJarsInDirectory(String, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
- 
Returns all jars that are in the directory. 
- getJitter() - Method in class org.apache.hadoop.fs.GetSpaceUsed.Builder
-  
- getKerberosInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.security.AnnotatedSecurityInfo
-  
- getKerberosInfo(Class<?>, Configuration) - Static method in class org.apache.hadoop.security.SecurityUtil
- 
Look up the KerberosInfo for a given protocol. 
- getKey() - Method in class org.apache.hadoop.conf.Configuration.DeprecationDelta
-  
- getKey(BytesWritable) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Copy the key into BytesWritable. 
- getKey(byte[]) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Copy the key into user supplied buffer. 
- getKey(byte[], int) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Copy the key into user supplied buffer. 
- getKey() - Method in interface org.apache.hadoop.io.SequenceFile.Sorter.RawKeyValueIterator
- 
Gets the current raw key 
- getKey() - Method in class org.apache.hadoop.io.SequenceFile.Sorter.SegmentDescriptor
- 
Returns the stored rawKey 
- getKey() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
- 
required string key = 1;
 
- getKey() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
- 
required string key = 1;
 
- getKey() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ConfigPairOrBuilder
- 
required string key = 1;
 
- getKeyBytes() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
- 
required string key = 1;
 
- getKeyBytes() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
- 
required string key = 1;
 
- getKeyBytes() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ConfigPairOrBuilder
- 
required string key = 1;
 
- getKeyClass() - Method in class org.apache.hadoop.io.MapFile.Reader
- 
Returns the class of keys in this file. 
- getKeyClass() - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Returns the class of keys in this file. 
- getKeyClass() - Method in class org.apache.hadoop.io.SequenceFile.Writer
- 
Returns the class of keys in this file. 
- getKeyClass() - Method in class org.apache.hadoop.io.WritableComparator
- 
Returns the WritableComparable implementation class. 
- getKeyClassName() - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Returns the name of the key class. 
- getKeyLength() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Get the length of the key. 
- getKeyNear(long) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get a sample key that is within a block whose starting offset is greater
 than or equal to the specified offset. 
- getKeyProvider() - Method in class org.apache.hadoop.crypto.key.KeyProviderExtension
-  
- getKeyProviderUri() - Method in class org.apache.hadoop.fs.FsServerDefaults
-  
- getKeys() - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Get the key names for all keys. 
- getKeys() - Method in class org.apache.hadoop.crypto.key.KeyProviderExtension
-  
- getKeys() - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- getKeysMetadata(String...) - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Get key metadata in bulk. 
- getKeysMetadata(String...) - Method in class org.apache.hadoop.crypto.key.KeyProviderExtension
-  
- getKeysMetadata(String...) - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- getKeyStream() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Streaming access to the key. 
- getKeytabFile() - Method in exception org.apache.hadoop.security.KerberosAuthException
-  
- getKeyTypeID() - Method in class org.apache.hadoop.record.meta.MapTypeID
- 
Deprecated. get the TypeID of the map's key element 
- getKeyVersion(String) - Method in class org.apache.hadoop.crypto.key.CachingKeyProvider
-  
- getKeyVersion(String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Get the key material for a specific version of the key. 
- getKeyVersion(String) - Method in class org.apache.hadoop.crypto.key.KeyProviderExtension
-  
- getKeyVersion(String) - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- getKeyVersions(String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Get the key material for all versions of a specific key name. 
- getKeyVersions(String) - Method in class org.apache.hadoop.crypto.key.KeyProviderExtension
-  
- getKeyVersions(String) - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- getKind() - Method in class org.apache.hadoop.crypto.key.kms.KMSDelegationToken.KMSDelegationTokenIdentifier
-  
- getKind() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required string kind = 3;
 
- getKind() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
- 
required string kind = 3;
 
- getKind() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.TokenProtoOrBuilder
- 
required string kind = 3;
 
- getKind() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenIdentifier
-  
- getKind() - Method in class org.apache.hadoop.security.token.Token
- 
Get the token kind 
- getKind() - Method in class org.apache.hadoop.security.token.Token.TrivialRenewer
-  
- getKind() - Method in class org.apache.hadoop.security.token.TokenIdentifier
- 
Get the token kind 
- getKindBytes() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required string kind = 3;
 
- getKindBytes() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
- 
required string kind = 3;
 
- getKindBytes() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.TokenProtoOrBuilder
- 
required string kind = 3;
 
- getKlass() - Method in class org.apache.hadoop.fs.GetSpaceUsed.Builder
-  
- getLargeReadOps() - Method in class org.apache.hadoop.fs.FileSystem.Statistics
- 
Get the number of large file system read operations such as list files
 under a large directory. 
- getLargeReadOps() - Method in class org.apache.hadoop.fs.FileSystem.Statistics.StatisticsData
-  
- getLastContact() - Method in class org.apache.hadoop.ipc.Server.Connection
-  
- getLastKey() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get the last key in the TFile. 
- getLastReportedTime() - Method in class org.apache.hadoop.util.NodeHealthScriptRunner
- 
Returns time stamp when node health script was last run. 
- getLatestGcData() - Method in class org.apache.hadoop.util.GcTimeMonitor
- 
Returns a copy of the most recent data measured by this monitor. 
- getLeaf(int, Node) - Method in class org.apache.hadoop.net.InnerNodeImpl
-  
- getLeasedCompressorsCount(CompressionCodec) - Static method in class org.apache.hadoop.io.compress.CodecPool
- 
- getLeasedDecompressorsCount(CompressionCodec) - Static method in class org.apache.hadoop.io.compress.CodecPool
- 
- getLen() - Method in class org.apache.hadoop.fs.FileStatus
- 
Get the length of this file, in bytes. 
- getLength() - Method in class org.apache.hadoop.fs.BlockLocation
- 
Get the length of the block 
- getLength() - Method in class org.apache.hadoop.fs.ContentSummary
-  
- getLength() - Method in class org.apache.hadoop.fs.FileChecksum
- 
The length of the checksum in bytes 
- getLength(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
- getLength() - Method in class org.apache.hadoop.io.BinaryComparable
- 
Return n st bytes 0..n-1 from {#getBytes()} are valid. 
- getLength() - Method in class org.apache.hadoop.io.BytesWritable
- 
Get the current size of the buffer. 
- getLength() - Method in class org.apache.hadoop.io.DataInputByteBuffer
-  
- getLength() - Method in class org.apache.hadoop.io.DataOutputByteBuffer
-  
- getLength() - Method in interface org.apache.hadoop.io.ReadaheadPool.ReadaheadRequest
-  
- getLength() - Method in class org.apache.hadoop.io.SequenceFile.Writer
- 
Returns the current length of the output file. 
- getLength() - Method in class org.apache.hadoop.io.Text
- 
Returns the number of bytes in the byte array 
- getLibraryName() - Static method in class org.apache.hadoop.io.compress.bzip2.Bzip2Compressor
-  
- getLibraryName(Configuration) - Static method in class org.apache.hadoop.io.compress.bzip2.Bzip2Factory
-  
- getLibraryName() - Static method in class org.apache.hadoop.io.compress.lz4.Lz4Compressor
-  
- getLibraryName() - Static method in class org.apache.hadoop.io.compress.Lz4Codec
-  
- getLibraryName() - Static method in class org.apache.hadoop.io.compress.snappy.SnappyCompressor
-  
- getLibraryName() - Static method in class org.apache.hadoop.io.compress.SnappyCodec
-  
- getLibraryName() - Static method in class org.apache.hadoop.io.compress.zlib.ZlibCompressor
-  
- getLibraryName() - Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
-  
- getLibraryName() - Static method in class org.apache.hadoop.io.compress.ZStandardCodec
-  
- getLibraryName() - Static method in class org.apache.hadoop.io.compress.zstd.ZStandardCompressor
-  
- getLifecycleHistory() - Method in class org.apache.hadoop.service.AbstractService
-  
- getLifecycleHistory() - Method in interface org.apache.hadoop.service.Service
- 
Get a snapshot of the lifecycle history; it is a static list 
- getLinkCount(File) - Static method in class org.apache.hadoop.fs.HardLink
- 
Retrieves the number of links to the specified file. 
- getLinkTarget(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Partially resolves the path. 
- getLinkTarget(Path) - Method in class org.apache.hadoop.fs.FileContext
- 
Returns the target of the given symbolic link as it was specified
 when the link was created. 
- getLinkTarget(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
- getLinkTarget(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getLinkTarget(Path) - Method in class org.apache.hadoop.fs.LocalFileSystem
-  
- getLinkTarget(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- getLinkTarget(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getListenerAddress() - Method in class org.apache.hadoop.ipc.Server
- 
Return the socket (ip+port) on which the RPC server is listening to. 
- getLoc(String) - Method in class org.apache.hadoop.net.InnerNodeImpl
-  
- getLocal(Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
- 
Get the local FileSystem. 
- getLocalFSFileContext() - Static method in class org.apache.hadoop.fs.FileContext
-  
- getLocalFSFileContext(Configuration) - Static method in class org.apache.hadoop.fs.FileContext
-  
- getLocalPath(String, String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get a local file under a directory named by dirsProp with
 the given path. 
- getLoginUser() - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Get the currently logged in user. 
- getLogSupressionMessage(LogThrottlingHelper.LogAction) - Static method in class org.apache.hadoop.log.LogThrottlingHelper
- 
Helper function to create a message about how many log statements were
 suppressed in the provided log action. 
- getLong(String, long) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as along.
 
- getLong(String) - Method in class org.apache.hadoop.fs.StorageStatistics
- 
Get the value of a statistic. 
- getLongBytes(String, long) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as alongor
 human readable format.
 
- getLongStatistics() - Method in class org.apache.hadoop.fs.StorageStatistics
- 
Get an iterator over all the currently tracked long statistics. 
- getMajor() - Method in class org.apache.hadoop.io.file.tfile.Utils.Version
- 
Get the major version. 
- getMasterKeyId() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenIdentifier
-  
- getMaterial() - Method in class org.apache.hadoop.crypto.key.KeyProvider.KeyVersion
-  
- getMaxDate() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenIdentifier
-  
- getMaxDepth() - Method in class org.apache.hadoop.fs.shell.find.FindOptions
- 
Returns the maximum depth for applying expressions. 
- getMaxIdleTime() - Method in class org.apache.hadoop.ipc.Server
-  
- getMaxQueueSize() - Method in class org.apache.hadoop.ipc.Server
- 
The maximum size of the rpc call queue of this server. 
- getMbeanNameName(ObjectName) - Static method in class org.apache.hadoop.metrics2.util.MBeans
-  
- getMbeanNameService(ObjectName) - Static method in class org.apache.hadoop.metrics2.util.MBeans
-  
- getMechanism() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
required string mechanism = 2;
 
- getMechanism() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
required string mechanism = 2;
 
- getMechanism() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
required string mechanism = 2;
 
- getMechanismBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
required string mechanism = 2;
 
- getMechanismBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
required string mechanism = 2;
 
- getMechanismBytes() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
required string mechanism = 2;
 
- getMechanismName() - Method in enum org.apache.hadoop.security.SaslRpcServer.AuthMethod
- 
Return the SASL mechanism name 
- getMechanismNames(Map<String, ?>) - Method in class org.apache.hadoop.security.SaslPlainServer.SaslPlainServerFactory
-  
- getMemlockLimit() - Method in class org.apache.hadoop.io.nativeio.NativeIO.POSIX.CacheManipulator
-  
- getMemlockLimit() - Method in class org.apache.hadoop.io.nativeio.NativeIO.POSIX.NoMlockCacheManipulator
-  
- getMemlockLimit(Long) - Static method in class org.apache.hadoop.util.Shell
- 
Static method to return the memory lock limit for datanode. 
- getMemory() - Method in class org.apache.hadoop.io.SequenceFile.Sorter
- 
Get the total amount of buffer memory, in bytes. 
- getMessage() - Method in exception org.apache.hadoop.fs.PathIOException
- 
Format:
 cmd: {operation} `path' {to `target'}: error string 
- getMessage() - Method in exception org.apache.hadoop.fs.shell.CommandFormat.IllegalNumberOfArgumentsException
-  
- getMessage() - Method in exception org.apache.hadoop.fs.shell.CommandFormat.NotEnoughArgumentsException
-  
- getMessage() - Method in exception org.apache.hadoop.fs.shell.CommandFormat.TooManyArgumentsException
-  
- getMessage() - Method in exception org.apache.hadoop.fs.viewfs.NotInMountpointException
-  
- getMessage() - Method in class org.apache.hadoop.ipc.RefreshResponse
-  
- getMessage() - Method in exception org.apache.hadoop.record.compiler.generated.ParseException
- 
Deprecated. This method has the standard behavior when this object has been
 created using the standard constructors. 
- getMessage() - Method in error org.apache.hadoop.record.compiler.generated.TokenMgrError
- 
Deprecated. You can also modify the body of this method to customize your error messages. 
- getMessage() - Method in exception org.apache.hadoop.security.KerberosAuthException
-  
- getMetaBlock(String) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Stream access to a meta block.`` 
- getMetadata(String) - Method in class org.apache.hadoop.crypto.key.CachingKeyProvider
-  
- getMetadata(String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
- 
Get metadata about the key. 
- getMetadata(String) - Method in class org.apache.hadoop.crypto.key.KeyProviderExtension
-  
- getMetadata(String) - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- getMetadata() - Method in class org.apache.hadoop.io.SequenceFile.Metadata
-  
- getMetadata() - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Returns the metadata object of the file 
- getMethod() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
required string method = 1;
 
- getMethod() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
required string method = 1;
 
- getMethod() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
required string method = 1;
 
- getMethod() - Method in interface org.apache.hadoop.security.http.RestCsrfPreventionFilter.HttpInteraction
- 
Returns the method. 
- getMethodBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
required string method = 1;
 
- getMethodBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
required string method = 1;
 
- getMethodBytes() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
required string method = 1;
 
- getMethodName() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required string methodName = 1;
 
- getMethodName() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
- 
required string methodName = 1;
 
- getMethodName() - Method in interface org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProtoOrBuilder
- 
required string methodName = 1;
 
- getMethodNameBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required string methodName = 1;
 
- getMethodNameBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
- 
required string methodName = 1;
 
- getMethodNameBytes() - Method in interface org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProtoOrBuilder
- 
required string methodName = 1;
 
- getMethods(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
- 
repeated uint32 methods = 2;
 
- getMethods(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
- 
repeated uint32 methods = 2;
 
- getMethods(int) - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProtoOrBuilder
- 
repeated uint32 methods = 2;
 
- getMethods() - Method in class org.apache.hadoop.ipc.ProtocolSignature
-  
- getMethodsCount() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
- 
repeated uint32 methods = 2;
 
- getMethodsCount() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
- 
repeated uint32 methods = 2;
 
- getMethodsCount() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProtoOrBuilder
- 
repeated uint32 methods = 2;
 
- getMethodsList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
- 
repeated uint32 methods = 2;
 
- getMethodsList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
- 
repeated uint32 methods = 2;
 
- getMethodsList() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProtoOrBuilder
- 
repeated uint32 methods = 2;
 
- getMetric(String) - Method in class org.apache.hadoop.metrics.spi.OutputRecord
- 
Deprecated. Returns the metric object which can be a Float, Integer, Short or Byte. 
- getMetric(String) - Method in class org.apache.hadoop.metrics2.util.MetricsCache.Record
- 
Lookup a metric value 
- getMetricInstance(String) - Method in class org.apache.hadoop.metrics2.util.MetricsCache.Record
- 
Lookup a metric instance 
- getMetricNames() - Method in class org.apache.hadoop.metrics.spi.OutputRecord
- 
Deprecated. Returns the set of metric names. 
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.ipc.DecayRpcScheduler
-  
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.ipc.DecayRpcScheduler.MetricsProxy
-  
- getMetrics(MetricsCollector, boolean) - Method in interface org.apache.hadoop.metrics2.MetricsSource
- 
Get metrics from the source 
- getMetricsCopy() - Method in class org.apache.hadoop.metrics.spi.OutputRecord
- 
Deprecated. Returns a copy of this record's metrics. 
- getMillisToCede() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto.Builder
- 
required uint32 millisToCede = 1;
 
- getMillisToCede() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto
- 
required uint32 millisToCede = 1;
 
- getMillisToCede() - Method in interface org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProtoOrBuilder
- 
required uint32 millisToCede = 1;
 
- getMinDepth() - Method in class org.apache.hadoop.fs.shell.find.FindOptions
- 
Returns the minimum depth for applying expressions. 
- getMinor() - Method in class org.apache.hadoop.io.file.tfile.Utils.Version
- 
Get the minor version. 
- getMode() - Method in class org.apache.hadoop.io.nativeio.NativeIO.POSIX.Stat
-  
- getModificationTime() - Method in class org.apache.hadoop.fs.FileStatus
- 
Get the modification time of the file. 
- getMountPoints() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getMountPoints() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getMovableTypes() - Static method in enum org.apache.hadoop.fs.StorageType
-  
- getMultipleLinearRandomRetry(Configuration, String, boolean, String, String) - Static method in class org.apache.hadoop.io.retry.RetryUtils
- 
Return the MultipleLinearRandomRetry policy specified in the conf,
 or null if the feature is disabled. 
- getName() - Method in class org.apache.hadoop.crypto.key.KeyProvider.KeyVersion
-  
- getName() - Method in interface org.apache.hadoop.fs.BlockStoragePolicySpi
- 
Return the name of the storage policy. 
- getName() - Method in class org.apache.hadoop.fs.FileSystem
- 
- getName() - Method in class org.apache.hadoop.fs.Path
- 
Returns the final component of this path. 
- getName() - Method in class org.apache.hadoop.fs.permission.AclEntry
- 
Returns the optional ACL entry name. 
- getName() - Method in class org.apache.hadoop.fs.StorageStatistics
- 
Get the name of this StorageStatistics object. 
- getName() - Method in class org.apache.hadoop.fs.StorageStatistics.LongStatistic
-  
- getName() - Method in enum org.apache.hadoop.io.file.tfile.Compression.Algorithm
-  
- getName() - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
- 
Deprecated. return the name of the record 
- getName() - Method in class org.apache.hadoop.service.AbstractService
-  
- getName() - Method in class org.apache.hadoop.service.launcher.IrqHandler.InterruptData
-  
- getName() - Method in interface org.apache.hadoop.service.Service
- 
Get the name of this service. 
- getNamed(String, Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
- 
- getNames() - Method in class org.apache.hadoop.fs.BlockLocation
- 
Get the list of names (IP:xferPort) hosting this block 
- getNestedStructTypeInfo(String) - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
- 
Deprecated. Return the type info of a nested record. 
- getNetworkBytesRead() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the aggregated number of bytes read over the network. 
- getNetworkBytesWritten() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the aggregated number of bytes written to the network. 
- getNewConf() - Method in class org.apache.hadoop.conf.ReconfigurableBase
- 
Create a new configuration. 
- getNewExpiryTime() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto.Builder
- 
required uint64 newExpiryTime = 1;
 
- getNewExpiryTime() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto
- 
required uint64 newExpiryTime = 1;
 
- getNewExpiryTime() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProtoOrBuilder
- 
required uint64 newExpiryTime = 1;
 
- getNewKeys() - Method in class org.apache.hadoop.conf.Configuration.DeprecationDelta
-  
- getNewValue() - Method in exception org.apache.hadoop.conf.ReconfigurationException
- 
Get value to which property was supposed to be changed. 
- getNext() - Method in class org.apache.hadoop.ipc.RetryCache.CacheEntry
-  
- getNext() - Method in interface org.apache.hadoop.util.LightWeightGSet.LinkedElement
- 
Get the next element. 
- getNextAncestorName(Node) - Method in class org.apache.hadoop.net.InnerNodeImpl
-  
- getNextToken() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
- 
Deprecated. 
- getNextToken() - Method in class org.apache.hadoop.record.compiler.generated.RccTokenManager
- 
Deprecated. 
- getNotReadyReason() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
- 
optional string notReadyReason = 3;
 
- getNotReadyReason() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
- 
optional string notReadyReason = 3;
 
- getNotReadyReason() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProtoOrBuilder
- 
optional string notReadyReason = 3;
 
- getNotReadyReasonBytes() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
- 
optional string notReadyReason = 3;
 
- getNotReadyReasonBytes() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
- 
optional string notReadyReason = 3;
 
- getNotReadyReasonBytes() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProtoOrBuilder
- 
optional string notReadyReason = 3;
 
- getNumber() - Method in enum org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HARequestSource
-  
- getNumber() - Method in enum org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceStateProto
-  
- getNumber() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcKindProto
-  
- getNumber() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.OperationProto
-  
- getNumber() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.RpcErrorCodeProto
-  
- getNumber() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.RpcStatusProto
-  
- getNumber() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslState
-  
- getNumber() - Method in class org.apache.hadoop.metrics.spi.MetricValue
- 
Deprecated. 
- getNumber() - Method in class org.apache.hadoop.service.launcher.IrqHandler.InterruptData
-  
- getNumCores() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain total number of physical cores present on the system. 
- getNumDroppedConnections() - Method in class org.apache.hadoop.ipc.Server
- 
The number of RPC connections dropped due to
 too many connections. 
- getNumOfLeaves() - Method in class org.apache.hadoop.net.InnerNodeImpl
-  
- getNumOpenConnections() - Method in class org.apache.hadoop.ipc.Server
- 
The number of open RPC conections 
- getNumOpenConnectionsPerUser() - Method in class org.apache.hadoop.ipc.Server
- 
Get the NumOpenConnections/User. 
- getNumProcessors() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the total number of logical processors present on the system. 
- getNumReaders() - Method in class org.apache.hadoop.ipc.Server
- 
The number of reader threads for this server. 
- getNumVCoresUsed() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the number of VCores used. 
- getOffset() - Method in class org.apache.hadoop.fs.BlockLocation
- 
Get the start offset of file associated with this block 
- getOffset() - Method in interface org.apache.hadoop.io.ReadaheadPool.ReadaheadRequest
-  
- getOldValue() - Method in exception org.apache.hadoop.conf.ReconfigurationException
- 
Get old value of property that cannot be changed. 
- getOperatingSystemPageSize() - Method in class org.apache.hadoop.io.nativeio.NativeIO.POSIX.CacheManipulator
-  
- getOperatingSystemPageSize() - Method in class org.apache.hadoop.io.nativeio.NativeIO.POSIX.NoMlockCacheManipulator
-  
- getOpt(String) - Method in class org.apache.hadoop.fs.shell.CommandFormat
- 
Return if the option is set or not 
- getOption() - Method in exception org.apache.hadoop.fs.shell.CommandFormat.UnknownOptionException
-  
- getOption(Class<T>, base[]) - Static method in class org.apache.hadoop.util.Options
- 
Find the first option of the required class. 
- getOptions() - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
- 
Return the options to be used by this expression. 
- getOpts() - Method in class org.apache.hadoop.fs.shell.CommandFormat
- 
Returns all the options that are set 
- getOptValue(String) - Method in class org.apache.hadoop.fs.shell.CommandFormat
- 
get the option's value 
- getOtherAction() - Method in class org.apache.hadoop.fs.permission.FsPermission
- 
- getOut() - Method in class org.apache.hadoop.fs.shell.find.FindOptions
- 
Returns the output stream to be used. 
- getOutput() - Method in interface org.apache.hadoop.util.Shell.CommandExecutor
-  
- getOutput() - Method in class org.apache.hadoop.util.Shell.ShellCommandExecutor
- 
Get the output of the shell command. 
- getOverflowedCalls() - Method in class org.apache.hadoop.ipc.FairCallQueue
-  
- getOverflowedCalls() - Method in interface org.apache.hadoop.ipc.FairCallQueueMXBean
-  
- getOwner() - Method in class org.apache.hadoop.fs.FileStatus
- 
Get the owner of the file. 
- getOwner() - Method in class org.apache.hadoop.fs.permission.AclStatus
- 
Returns the file owner. 
- getOwner() - Method in class org.apache.hadoop.io.nativeio.NativeIO.POSIX.Stat
-  
- getOwner() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenIdentifier
-  
- getParameter(String) - Method in class org.apache.hadoop.http.HttpServer.QuotingInputFilter.RequestQuoter
- 
Deprecated. Unquote the name and quote the value. 
- getParameter(String) - Method in class org.apache.hadoop.http.HttpServer2.QuotingInputFilter.RequestQuoter
- 
Unquote the name and quote the value. 
- getParameterMap() - Method in class org.apache.hadoop.http.HttpServer.QuotingInputFilter.RequestQuoter
- 
Deprecated. 
- getParameterMap() - Method in class org.apache.hadoop.http.HttpServer2.QuotingInputFilter.RequestQuoter
-  
- getParameterNames() - Method in class org.apache.hadoop.http.HttpServer.QuotingInputFilter.RequestQuoter
- 
Deprecated. Return the set of parameter names, quoting each name. 
- getParameterNames() - Method in class org.apache.hadoop.http.HttpServer2.QuotingInputFilter.RequestQuoter
- 
Return the set of parameter names, quoting each name. 
- getParameterValues(String) - Method in class org.apache.hadoop.http.HttpServer.QuotingInputFilter.RequestQuoter
- 
Deprecated. 
- getParameterValues(String) - Method in class org.apache.hadoop.http.HttpServer2.QuotingInputFilter.RequestQuoter
-  
- getParent() - Method in class org.apache.hadoop.fs.Path
- 
Returns the parent of a path or null if at root. 
- getParentId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
- 
optional int64 parentId = 2;
 
- getParentId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
- 
optional int64 parentId = 2;
 
- getParentId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProtoOrBuilder
- 
optional int64 parentId = 2;
 
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
-  
- getParserForType() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
-  
- getParserForType() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
-  
- getParserForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto
-  
- getParserForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto
-  
- getParserForType() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
-  
- getPassword(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value for a known password configuration element. 
- getPassword() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required bytes password = 2;
 
- getPassword() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
- 
required bytes password = 2;
 
- getPassword() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.TokenProtoOrBuilder
- 
required bytes password = 2;
 
- getPassword() - Method in class org.apache.hadoop.security.token.Token
- 
Get the token password/secret 
- getPasswordFromConfig(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Fallback to clear text passwords in configuration. 
- getPasswordFromCredentialProviders(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Try and resolve the provided element name as a credential provider
 alias. 
- getPasswordReader() - Method in class org.apache.hadoop.security.alias.CredentialShell
-  
- getPath() - Method in class org.apache.hadoop.fs.FileStatus
-  
- getPath() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
-  
- getPath() - Method in class org.apache.hadoop.fs.GetSpaceUsed.Builder
-  
- getPath() - Method in exception org.apache.hadoop.fs.PathIOException
-  
- getPath(PathData) - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
- 
Returns the  Path from the  PathData item. 
- getPathWithoutSchemeAndAuthority(Path) - Static method in class org.apache.hadoop.fs.Path
- 
Return a version of the given Path without the scheme information. 
- getPattern(String, Pattern) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as aPattern.
 
- getPayload() - Method in class org.apache.hadoop.ipc.RetryCache.CacheEntryWithPayload
-  
- getPeriod() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- 
Deprecated. Returns the timer period. 
- getPermission() - Method in class org.apache.hadoop.fs.FileStatus
- 
Get FsPermission associated with the file. 
- getPermission() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
-  
- getPermission() - Method in class org.apache.hadoop.fs.permission.AclEntry
- 
Returns the set of permissions in the ACL entry. 
- getPermission() - Method in class org.apache.hadoop.fs.permission.AclStatus
- 
Returns the permission set for the path 
- getPhysicalMemorySize() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the total size of the physical memory present in the system. 
- getPingInterval(Configuration) - Static method in class org.apache.hadoop.ipc.Client
- 
Get the ping interval from configuration;
 If not set in the configuration, return the default value. 
- getPort() - Method in class org.apache.hadoop.ipc.Server
- 
Get the port on which the IPC Server is listening for incoming connections. 
- getPos() - Method in exception org.apache.hadoop.fs.ChecksumException
-  
- getPos() - Method in class org.apache.hadoop.fs.crypto.CryptoFSDataOutputStream
-  
- getPos() - Method in class org.apache.hadoop.fs.FSDataInputStream
- 
Get the current position in the input stream. 
- getPos() - Method in class org.apache.hadoop.fs.FSDataOutputStream
- 
Get the current position in the output stream. 
- getPos() - Method in class org.apache.hadoop.fs.FSInputStream
- 
Return the current offset from the start of the file 
- getPos() - Method in interface org.apache.hadoop.fs.Seekable
- 
Return the current offset from the start of the file 
- getPos() - Method in class org.apache.hadoop.io.compress.CompressionInputStream
- 
This method returns the current position in the stream. 
- getPosition() - Method in class org.apache.hadoop.io.DataInputByteBuffer
-  
- getPosition() - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Return the current byte position in the input file. 
- getPrecedence() - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
-  
- getPrecedence() - Method in interface org.apache.hadoop.fs.shell.find.Expression
- 
Returns the precedence of this expression
 (only applicable to operators). 
- getPrecedence() - Method in class org.apache.hadoop.fs.shell.find.FilterExpression
-  
- getPrefix() - Method in class org.apache.hadoop.security.HttpCrossOriginFilterInitializer
-  
- getPrimaryGroupName() - Method in class org.apache.hadoop.security.UserGroupInformation
-  
- getPrincipal() - Method in exception org.apache.hadoop.security.KerberosAuthException
-  
- getPriorityLevel(Schedulable) - Method in class org.apache.hadoop.ipc.DecayRpcScheduler
- 
Compute the appropriate priority for a schedulable based on past requests. 
- getPriorityLevel(Schedulable) - Method in class org.apache.hadoop.ipc.DefaultRpcScheduler
-  
- getPriorityLevel(Schedulable) - Method in interface org.apache.hadoop.ipc.RpcScheduler
- 
Returns priority level greater than zero as a hint for scheduling. 
- getPriorityLevel() - Method in class org.apache.hadoop.ipc.Server.Call
-  
- getPriorityLevel() - Static method in class org.apache.hadoop.ipc.Server
- 
Return the priority level assigned by call queue to an RPC
 Returns 0 in case no priority is assigned. 
- getProcess() - Method in class org.apache.hadoop.util.Shell
- 
get the current sub-process executing the given command. 
- getProcessedByteCount() - Method in class org.apache.hadoop.io.compress.bzip2.CBZip2InputStream
- 
This method reports the processed bytes so far. 
- getProcessingDetails() - Method in class org.apache.hadoop.ipc.Server.Call
-  
- getProgress() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
-  
- getProgress() - Method in interface org.apache.hadoop.io.SequenceFile.Sorter.RawKeyValueIterator
- 
Gets the Progress object; this has a float (0.0 - 1.0) 
 indicating the bytes processed by the iterator so far 
- getProperty() - Method in exception org.apache.hadoop.conf.ReconfigurationException
- 
Get property that cannot be changed. 
- getPropertySources(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Gets information about why a property was set. 
- getProps() - Method in class org.apache.hadoop.conf.Configuration
-  
- getPropsWithPrefix(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Constructs a mapping of configuration and includes all properties that
 start with the specified configuration prefix. 
- getProtocol() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
- 
optional string protocol = 3;
 
- getProtocol() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
- 
optional string protocol = 3;
 
- getProtocol() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProtoOrBuilder
- 
optional string protocol = 3;
 
- getProtocol() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
- 
required string protocol = 1;
 
- getProtocol() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
- 
required string protocol = 1;
 
- getProtocol() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProtoOrBuilder
- 
required string protocol = 1;
 
- getProtocol() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto.Builder
- 
required string protocol = 1;
 
- getProtocol() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto
- 
required string protocol = 1;
 
- getProtocol() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProtoOrBuilder
- 
required string protocol = 1;
 
- getProtocol() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional string protocol = 3;
 
- getProtocol() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
optional string protocol = 3;
 
- getProtocol() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
optional string protocol = 3;
 
- getProtocol() - Method in class org.apache.hadoop.ipc.Server.Call
-  
- getProtocol() - Static method in class org.apache.hadoop.ipc.Server
-  
- getProtocolAddress(Configuration) - Method in class org.apache.hadoop.tools.GetGroupsBase
- 
Must be overridden by subclasses to get the address where the
 GetUserMappingsProtocolimplementation is running.
 
- getProtocolBytes() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
- 
optional string protocol = 3;
 
- getProtocolBytes() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
- 
optional string protocol = 3;
 
- getProtocolBytes() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProtoOrBuilder
- 
optional string protocol = 3;
 
- getProtocolBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
- 
required string protocol = 1;
 
- getProtocolBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
- 
required string protocol = 1;
 
- getProtocolBytes() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProtoOrBuilder
- 
required string protocol = 1;
 
- getProtocolBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto.Builder
- 
required string protocol = 1;
 
- getProtocolBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto
- 
required string protocol = 1;
 
- getProtocolBytes() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProtoOrBuilder
- 
required string protocol = 1;
 
- getProtocolBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional string protocol = 3;
 
- getProtocolBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
optional string protocol = 3;
 
- getProtocolBytes() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
optional string protocol = 3;
 
- getProtocolMetaInfoProxy(Client.ConnectionId, Configuration, SocketFactory) - Method in class org.apache.hadoop.ipc.ProtobufRpcEngine
-  
- getProtocolMetaInfoProxy(Client.ConnectionId, Configuration, SocketFactory) - Method in interface org.apache.hadoop.ipc.RpcEngine
- 
Returns a proxy for ProtocolMetaInfoPB, which uses the given connection
 id. 
- getProtocolMetaInfoProxy(Client.ConnectionId, Configuration, SocketFactory) - Method in class org.apache.hadoop.ipc.WritableRpcEngine
-  
- getProtocolName() - Method in class org.apache.hadoop.ipc.ProtobufRpcEngine.Invoker
-  
- getProtocolSignature(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignature(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignature(int) - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProtoOrBuilder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignature(RpcController, ProtocolInfoProtos.GetProtocolSignatureRequestProto) - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService.BlockingInterface
-  
- getProtocolSignature(RpcController, ProtocolInfoProtos.GetProtocolSignatureRequestProto, RpcCallback<ProtocolInfoProtos.GetProtocolSignatureResponseProto>) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService
- 
rpc getProtocolSignature(.hadoop.common.GetProtocolSignatureRequestProto) returns (.hadoop.common.GetProtocolSignatureResponseProto);
 
- getProtocolSignature(RpcController, ProtocolInfoProtos.GetProtocolSignatureRequestProto, RpcCallback<ProtocolInfoProtos.GetProtocolSignatureResponseProto>) - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService.Interface
- 
rpc getProtocolSignature(.hadoop.common.GetProtocolSignatureRequestProto) returns (.hadoop.common.GetProtocolSignatureResponseProto);
 
- getProtocolSignature(RpcController, ProtocolInfoProtos.GetProtocolSignatureRequestProto, RpcCallback<ProtocolInfoProtos.GetProtocolSignatureResponseProto>) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService.Stub
-  
- getProtocolSignature(RpcController, ProtocolInfoProtos.GetProtocolSignatureRequestProto) - Method in class org.apache.hadoop.ipc.ProtocolMetaInfoServerSideTranslatorPB
-  
- getProtocolSignature(int, long, Class<? extends VersionedProtocol>) - Static method in class org.apache.hadoop.ipc.ProtocolSignature
- 
Get a server protocol's signature 
- getProtocolSignature(String, long) - Static method in class org.apache.hadoop.ipc.ProtocolSignature
-  
- getProtocolSignature(VersionedProtocol, String, long, int) - Static method in class org.apache.hadoop.ipc.ProtocolSignature
- 
Get a server protocol's signature 
- getProtocolSignature(String, long, int) - Method in interface org.apache.hadoop.ipc.VersionedProtocol
- 
Return protocol version corresponding to protocol interface. 
- getProtocolSignatureBuilder(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureBuilderList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureCount() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureCount() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureCount() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProtoOrBuilder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureList() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProtoOrBuilder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureOrBuilder(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureOrBuilder(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureOrBuilder(int) - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProtoOrBuilder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureOrBuilderList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto.Builder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureOrBuilderList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolSignatureOrBuilderList() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProtoOrBuilder
- 
repeated .hadoop.common.ProtocolSignatureProto protocolSignature = 1;
 
- getProtocolVersion(String, long) - Method in interface org.apache.hadoop.ipc.VersionedProtocol
- 
Return protocol version corresponding to protocol interface. 
- getProtocolVersions(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersions(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersions(int) - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProtoOrBuilder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersions(RpcController, ProtocolInfoProtos.GetProtocolVersionsRequestProto) - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService.BlockingInterface
-  
- getProtocolVersions(RpcController, ProtocolInfoProtos.GetProtocolVersionsRequestProto, RpcCallback<ProtocolInfoProtos.GetProtocolVersionsResponseProto>) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService
- 
rpc getProtocolVersions(.hadoop.common.GetProtocolVersionsRequestProto) returns (.hadoop.common.GetProtocolVersionsResponseProto);
 
- getProtocolVersions(RpcController, ProtocolInfoProtos.GetProtocolVersionsRequestProto, RpcCallback<ProtocolInfoProtos.GetProtocolVersionsResponseProto>) - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService.Interface
- 
rpc getProtocolVersions(.hadoop.common.GetProtocolVersionsRequestProto) returns (.hadoop.common.GetProtocolVersionsResponseProto);
 
- getProtocolVersions(RpcController, ProtocolInfoProtos.GetProtocolVersionsRequestProto, RpcCallback<ProtocolInfoProtos.GetProtocolVersionsResponseProto>) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService.Stub
-  
- getProtocolVersions(RpcController, ProtocolInfoProtos.GetProtocolVersionsRequestProto) - Method in class org.apache.hadoop.ipc.ProtocolMetaInfoServerSideTranslatorPB
-  
- getProtocolVersionsBuilder(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsBuilderList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsCount() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsCount() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsCount() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProtoOrBuilder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsList() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProtoOrBuilder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsOrBuilder(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsOrBuilder(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsOrBuilder(int) - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProtoOrBuilder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsOrBuilderList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto.Builder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsOrBuilderList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocolVersionsOrBuilderList() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProtoOrBuilder
- 
repeated .hadoop.common.ProtocolVersionProto protocolVersions = 1;
 
- getProtocVersion() - Static method in class org.apache.hadoop.util.VersionInfo
- 
Returns the protoc version used for the build. 
- getProviders(Configuration) - Static method in class org.apache.hadoop.crypto.key.KeyProviderFactory
-  
- getProviders() - Method in class org.apache.hadoop.crypto.key.kms.LoadBalancingKMSClientProvider
-  
- getProviders(Configuration) - Static method in class org.apache.hadoop.security.alias.CredentialProviderFactory
-  
- getProxy(Configuration, int) - Method in class org.apache.hadoop.ha.HAServiceTarget
-  
- getProxy() - Method in class org.apache.hadoop.io.retry.DefaultFailoverProxyProvider
-  
- getProxy() - Method in interface org.apache.hadoop.io.retry.FailoverProxyProvider
- 
Get the proxy object which should be used until the next failover event
 occurs. 
- getProxy(Class<T>, long, InetSocketAddress, UserGroupInformation, Configuration, SocketFactory, int) - Method in class org.apache.hadoop.ipc.ProtobufRpcEngine
-  
- getProxy(Class<T>, long, InetSocketAddress, UserGroupInformation, Configuration, SocketFactory, int, RetryPolicy) - Method in class org.apache.hadoop.ipc.ProtobufRpcEngine
-  
- getProxy(Class<T>, long, InetSocketAddress, UserGroupInformation, Configuration, SocketFactory, int, RetryPolicy, AtomicBoolean, AlignmentContext) - Method in class org.apache.hadoop.ipc.ProtobufRpcEngine
-  
- getProxy() - Method in class org.apache.hadoop.ipc.ProtocolProxy
-  
- getProxy(Class<T>, long, InetSocketAddress, UserGroupInformation, Configuration, SocketFactory, int, RetryPolicy) - Method in interface org.apache.hadoop.ipc.RpcEngine
- 
Construct a client-side proxy object. 
- getProxy(Class<T>, long, InetSocketAddress, UserGroupInformation, Configuration, SocketFactory, int, RetryPolicy, AtomicBoolean, AlignmentContext) - Method in interface org.apache.hadoop.ipc.RpcEngine
- 
Construct a client-side proxy object. 
- getProxy(Class<T>, long, InetSocketAddress, UserGroupInformation, Configuration, SocketFactory, int, RetryPolicy) - Method in class org.apache.hadoop.ipc.WritableRpcEngine
- 
Construct a client-side proxy object that implements the named protocol,
 talking to a server at the named address. 
- getProxy(Class<T>, long, InetSocketAddress, UserGroupInformation, Configuration, SocketFactory, int, RetryPolicy, AtomicBoolean, AlignmentContext) - Method in class org.apache.hadoop.ipc.WritableRpcEngine
- 
Construct a client-side proxy object that implements the named protocol,
 talking to a server at the named address. 
- getProxyGroups() - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
-  
- getProxyHosts() - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
-  
- getProxySuperuserGroupConfKey(String) - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
- 
Returns configuration key for effective groups allowed for a superuser 
- getProxySuperuserIpConfKey(String) - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
- 
Return configuration key for superuser ip addresses 
- getProxySuperuserUserConfKey(String) - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
- 
Returns configuration key for effective usergroups allowed for a superuser 
- getQualifiedBin(String) - Static method in class org.apache.hadoop.util.Shell
- 
Fully qualify the path to a binary that should be in a known hadoop
  bin location. 
- getQualifiedBinPath(String) - Static method in class org.apache.hadoop.util.Shell
- 
Fully qualify the path to a binary that should be in a known hadoop
  bin location. 
- getQueueSizes() - Method in class org.apache.hadoop.ipc.FairCallQueue
-  
- getQueueSizes() - Method in interface org.apache.hadoop.ipc.FairCallQueueMXBean
-  
- getQuota() - Method in class org.apache.hadoop.fs.QuotaUsage
- 
Return the directory quota. 
- getQuotaHeaderFields() - Static method in class org.apache.hadoop.fs.ContentSummary
- 
Returns the names of the fields used in the quota summary. 
- getQuotaUsage(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
- getQuotaUsage(boolean) - Method in class org.apache.hadoop.fs.QuotaUsage
-  
- getQuotaUsage(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getRange(String, String) - Method in class org.apache.hadoop.conf.Configuration
- 
Parse the given attribute as a set of integer ranges 
- getRangeStart() - Method in class org.apache.hadoop.conf.Configuration.IntegerRanges
- 
Get range start for the first integer range. 
- getRaw(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the  name property, without doing
  variable expansion.If the key is 
 deprecated, it returns the value of the first key which replaces 
 the deprecated key and is not null. 
- getRaw() - Method in class org.apache.hadoop.fs.LocalFileSystem
-  
- getRawFileSystem() - Method in class org.apache.hadoop.fs.ChecksumFileSystem
- 
get the raw file system 
- getRawFileSystem() - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
Get the raw file system 
- getReadlinkCommand(String) - Static method in class org.apache.hadoop.util.Shell
- 
Return a command to read the target of the a symbolic link. 
- getReadOps() - Method in class org.apache.hadoop.fs.FileSystem.Statistics
- 
Get the number of file system read operations such as list files. 
- getReadOps() - Method in class org.apache.hadoop.fs.FileSystem.Statistics.StatisticsData
-  
- getReadyToBecomeActive() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
- 
optional bool readyToBecomeActive = 2;
 
- getReadyToBecomeActive() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
- 
optional bool readyToBecomeActive = 2;
 
- getReadyToBecomeActive() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProtoOrBuilder
- 
optional bool readyToBecomeActive = 2;
 
- getRealAuthenticationMethod() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Get the authentication method from the real user's subject. 
- getRealAuthenticationMethod(UserGroupInformation) - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Returns the authentication method of a ugi. 
- getRealUser() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
- 
optional string realUser = 2;
 
- getRealUser() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
- 
optional string realUser = 2;
 
- getRealUser() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProtoOrBuilder
- 
optional string realUser = 2;
 
- getRealUser() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenIdentifier
-  
- getRealUser() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
get RealUser (vs. 
- getRealUserBytes() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
- 
optional string realUser = 2;
 
- getRealUserBytes() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
- 
optional string realUser = 2;
 
- getRealUserBytes() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProtoOrBuilder
- 
optional string realUser = 2;
 
- getRealUserOrSelf(UserGroupInformation) - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
If this is a proxy user, get the real user. 
- getRecommendedBufferSize() - Static method in class org.apache.hadoop.io.compress.zstd.ZStandardCompressor
-  
- getRecommendedBufferSize() - Static method in class org.apache.hadoop.io.compress.zstd.ZStandardDecompressor
-  
- getReconfigurableProperties() - Method in interface org.apache.hadoop.conf.Reconfigurable
- 
Return all the properties that can be changed at run time. 
- getReconfigurableProperties() - Method in class org.apache.hadoop.conf.ReconfigurableBase
- 
Return all the properties that can be changed at run time. 
- getReconfigurationTaskStatus() - Method in class org.apache.hadoop.conf.ReconfigurableBase
-  
- getRecordName() - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
- 
Deprecated. Returns the record name. 
- getRecordNum() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner
- 
Get the RecordNum corresponding to the entry pointed by the cursor. 
- getRecordNumNear(long) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader
- 
Get the RecordNum for the first key-value pair in a compressed block
 whose byte offset in the TFile is greater than or equal to the specified
 offset. 
- getReferenceCount() - Method in class org.apache.hadoop.util.CloseableReferenceCount
- 
Get the current reference count. 
- getRemaining() - Method in class org.apache.hadoop.fs.FsStatus
- 
Return the number of remaining bytes on the file system 
- getRemaining() - Method in class org.apache.hadoop.io.compress.bzip2.Bzip2Decompressor
- 
Returns the number of bytes remaining in the input buffers; normally
 called when finished() is true to determine amount of post-gzip-stream
 data. 
- getRemaining() - Method in class org.apache.hadoop.io.compress.bzip2.BZip2DummyDecompressor
-  
- getRemaining() - Method in interface org.apache.hadoop.io.compress.Decompressor
- 
Returns the number of bytes remaining in the compressed data buffer. 
- getRemaining() - Method in class org.apache.hadoop.io.compress.lz4.Lz4Decompressor
- 
Returns 0.
 
- getRemaining() - Method in class org.apache.hadoop.io.compress.snappy.SnappyDecompressor
- 
Returns 0.
 
- getRemaining() - Method in class org.apache.hadoop.io.compress.zlib.BuiltInGzipDecompressor
- 
Returns the number of bytes remaining in the input buffer; normally
 called when finished() is true to determine amount of post-gzip-stream
 data. 
- getRemaining() - Method in class org.apache.hadoop.io.compress.zlib.ZlibDecompressor
- 
Returns the number of bytes remaining in the input buffers; normally
 called when finished() is true to determine amount of post-gzip-stream
 data. 
- getRemaining() - Method in class org.apache.hadoop.io.compress.zstd.ZStandardDecompressor
- 
Returns the number of bytes remaining in the input buffers;
 normally called when finished() is true to determine amount of post-stream
 data. 
- getRemoteAddress() - Static method in class org.apache.hadoop.ipc.Server
- 
Returns remote address as a string when invoked inside an RPC. 
- getRemoteIp() - Static method in class org.apache.hadoop.ipc.Server
- 
Returns the remote side ip address when invoked inside an RPC 
  Returns null incase of an error. 
- getRemoteUser() - Method in class org.apache.hadoop.ipc.ExternalCall
-  
- getRemoteUser() - Method in class org.apache.hadoop.ipc.Server.Call
-  
- getRemoteUser() - Static method in class org.apache.hadoop.ipc.Server
- 
Returns the RPC remote user when invoked inside an RPC. 
- getRenewDate() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager.DelegationTokenInformation
- 
returns renew date 
- getRenewer() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto.Builder
- 
required string renewer = 1;
 
- getRenewer() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto
- 
required string renewer = 1;
 
- getRenewer() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProtoOrBuilder
- 
required string renewer = 1;
 
- getRenewer() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenIdentifier
-  
- getRenewerBytes() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto.Builder
- 
required string renewer = 1;
 
- getRenewerBytes() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto
- 
required string renewer = 1;
 
- getRenewerBytes() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProtoOrBuilder
- 
required string renewer = 1;
 
- getRenewToken() - Method in interface org.apache.hadoop.fs.DelegationTokenRenewer.Renewable
-  
- getReplication() - Method in class org.apache.hadoop.fs.FileStatus
- 
Get the replication factor of a file. 
- getReplication(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
- getReplication() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
-  
- getReplication() - Method in class org.apache.hadoop.fs.FsServerDefaults
-  
- getReplicationFallbacks() - Method in interface org.apache.hadoop.fs.BlockStoragePolicySpi
- 
Get the fallback storage types for replicating existing block replicas. 
- getReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfo() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProtoOrBuilder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfo() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProtoOrBuilder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfo() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProtoOrBuilder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoBuilder() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoBuilder() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoBuilder() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoOrBuilder() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoOrBuilder() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoOrBuilder() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProtoOrBuilder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoOrBuilder() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoOrBuilder() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoOrBuilder() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProtoOrBuilder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoOrBuilder() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoOrBuilder() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqInfoOrBuilder() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProtoOrBuilder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- getReqSource() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto.Builder
- 
required .hadoop.common.HARequestSource reqSource = 1;
 
- getReqSource() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto
- 
required .hadoop.common.HARequestSource reqSource = 1;
 
- getReqSource() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProtoOrBuilder
- 
required .hadoop.common.HARequestSource reqSource = 1;
 
- getRequestLog(String) - Static method in class org.apache.hadoop.http.HttpRequestLog
-  
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService
-  
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService
-  
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshProtocolService
-  
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueProtocolService
-  
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService
-  
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshAuthorizationPolicyProtocolService
-  
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserMappingsProtocolService
-  
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService
-  
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.tracing.TraceAdminPB.TraceAdminService
-  
- getRequestURL() - Method in class org.apache.hadoop.http.HttpServer.QuotingInputFilter.RequestQuoter
- 
Deprecated. Quote the url so that users specifying the HOST HTTP header
 can't inject attacks. 
- getRequestURL() - Method in class org.apache.hadoop.http.HttpServer2.QuotingInputFilter.RequestQuoter
- 
Quote the url so that users specifying the HOST HTTP header
 can't inject attacks. 
- getResource(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the  URL for the named resource. 
- getResource(String) - Method in class org.apache.hadoop.util.ApplicationClassLoader
-  
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService
-  
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService
-  
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshProtocolService
-  
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueProtocolService
-  
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolInfoService
-  
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshAuthorizationPolicyProtocolService
-  
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserMappingsProtocolService
-  
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService
-  
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.tracing.TraceAdminPB.TraceAdminService
-  
- getResponses(int) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponses(int) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponses(int) - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProtoOrBuilder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesBuilder(int) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesBuilderList() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesCount() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesCount() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesCount() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProtoOrBuilder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesList() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesList() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesList() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProtoOrBuilder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesOrBuilder(int) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesOrBuilder(int) - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesOrBuilder(int) - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProtoOrBuilder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesOrBuilderList() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto.Builder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesOrBuilderList() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponsesOrBuilderList() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProtoOrBuilder
- 
repeated .hadoop.common.GenericRefreshResponseProto responses = 1;
 
- getResponseTimeCountInLastWindow() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler
-  
- getResponseTimeCountInLastWindow() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler.MetricsProxy
-  
- getResponseTimeCountInLastWindow() - Method in interface org.apache.hadoop.ipc.DecayRpcSchedulerMXBean
-  
- getRetainDays() - Method in class org.apache.hadoop.http.HttpRequestLogAppender
-  
- getRetryCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional sint32 retryCount = 5 [default = -1];
 
- getRetryCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional sint32 retryCount = 5 [default = -1];
 
- getRetryCount() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional sint32 retryCount = 5 [default = -1];
 
- getRetryCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional sint32 retryCount = 8 [default = -1];
 
- getRetryCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional sint32 retryCount = 8 [default = -1];
 
- getRetryCount() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional sint32 retryCount = 8 [default = -1];
 
- getReturnCode() - Method in class org.apache.hadoop.ipc.RefreshResponse
-  
- getRevision() - Method in interface org.apache.hadoop.ipc.FairCallQueueMXBean
-  
- getRevision() - Static method in class org.apache.hadoop.util.VersionInfo
- 
Get the Git commit hash of the repository when compiled. 
- getRollInterval() - Method in class org.apache.hadoop.metrics2.sink.RollingFileSystemSink
- 
Extract the roll interval from the configuration and return it in
 milliseconds. 
- getRpcDetailedMetrics() - Method in class org.apache.hadoop.ipc.Server
-  
- getRpcErrorCodeProto() - Method in exception org.apache.hadoop.ipc.RPC.VersionMismatch
- 
get the detailed rpc status corresponding to this exception 
- getRpcErrorCodeProto() - Method in exception org.apache.hadoop.ipc.RpcNoSuchMethodException
- 
get the detailed rpc status corresponding to this exception 
- getRpcErrorCodeProto() - Method in exception org.apache.hadoop.ipc.RpcNoSuchProtocolException
- 
get the detailed rpc status corresponding to this exception 
- getRpcErrorCodeProto() - Method in exception org.apache.hadoop.ipc.RpcServerException
- 
get the detailed rpc status corresponding to this exception 
- getRpcInvoker(RPC.RpcKind) - Static method in class org.apache.hadoop.ipc.Server
-  
- getRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
- 
required string rpcKind = 2;
 
- getRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
- 
required string rpcKind = 2;
 
- getRpcKind() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProtoOrBuilder
- 
required string rpcKind = 2;
 
- getRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
- 
required string rpcKind = 1;
 
- getRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
- 
required string rpcKind = 1;
 
- getRpcKind() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProtoOrBuilder
- 
required string rpcKind = 1;
 
- getRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RpcKindProto rpcKind = 1;
 
- getRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional .hadoop.common.RpcKindProto rpcKind = 1;
 
- getRpcKind() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional .hadoop.common.RpcKindProto rpcKind = 1;
 
- getRpcKindBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
- 
required string rpcKind = 2;
 
- getRpcKindBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
- 
required string rpcKind = 2;
 
- getRpcKindBytes() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProtoOrBuilder
- 
required string rpcKind = 2;
 
- getRpcKindBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
- 
required string rpcKind = 1;
 
- getRpcKindBytes() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
- 
required string rpcKind = 1;
 
- getRpcKindBytes() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProtoOrBuilder
- 
required string rpcKind = 1;
 
- getRpcMetrics() - Method in class org.apache.hadoop.ipc.Server
- 
Returns a handle to the rpcMetrics (required in tests) 
- getRpcOp() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2;
 
- getRpcOp() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2;
 
- getRpcOp() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2;
 
- getRpcRequestWrapper(RpcHeaderProtos.RpcKindProto) - Method in class org.apache.hadoop.ipc.Server
-  
- getRpcStatusProto() - Method in exception org.apache.hadoop.ipc.RPC.VersionMismatch
- 
get the rpc status corresponding to this exception 
- getRpcStatusProto() - Method in exception org.apache.hadoop.ipc.RpcNoSuchMethodException
- 
get the rpc status corresponding to this exception 
- getRpcStatusProto() - Method in exception org.apache.hadoop.ipc.RpcNoSuchProtocolException
- 
get the rpc status corresponding to this exception 
- getRpcStatusProto() - Method in exception org.apache.hadoop.ipc.RpcServerException
- 
get the rpc status corresponding to this exception 
- getRpcTimeout(Configuration) - Static method in class org.apache.hadoop.ipc.Client
- 
The time after which a RPC will timeout. 
- getRunScriptCommand(File) - Static method in class org.apache.hadoop.util.Shell
- 
Returns a command to run the given script. 
- getSaslQop() - Method in enum org.apache.hadoop.security.SaslRpcServer.QualityOfProtection
-  
- getSchedulingDecisionSummary() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler
-  
- getSchedulingDecisionSummary() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler.MetricsProxy
-  
- getSchedulingDecisionSummary() - Method in interface org.apache.hadoop.ipc.DecayRpcSchedulerMXBean
-  
- getScheme() - Method in class org.apache.hadoop.fs.FileSystem
- 
Return the protocol scheme for this FileSystem. 
- getScheme() - Method in class org.apache.hadoop.fs.FileSystem.Statistics
- 
Get the uri scheme associated with this statistics object. 
- getScheme() - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
- 
Return the protocol scheme for the FileSystem. 
- getScheme() - Method in class org.apache.hadoop.fs.HarFileSystem
- 
Return the protocol scheme for the FileSystem. 
- getScheme() - Method in class org.apache.hadoop.fs.http.HttpFileSystem
-  
- getScheme() - Method in class org.apache.hadoop.fs.http.HttpsFileSystem
-  
- getScheme() - Method in class org.apache.hadoop.fs.LocalFileSystem
- 
Return the protocol scheme for the FileSystem. 
- getScheme() - Method in class org.apache.hadoop.fs.StorageStatistics
-  
- getScheme() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
- 
Return the protocol scheme for the FileSystem. 
- getScope() - Method in class org.apache.hadoop.fs.permission.AclEntry
- 
Returns the scope of the ACL entry. 
- getSecretKey(Text) - Method in class org.apache.hadoop.security.Credentials
- 
Returns the key bytes for the alias 
- getSenderName() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional string senderName = 3;
 
- getSenderName() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
- 
optional string senderName = 3;
 
- getSenderName() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProtoOrBuilder
- 
optional string senderName = 3;
 
- getSenderName() - Method in class org.apache.hadoop.ipc.RefreshResponse
-  
- getSenderNameBytes() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional string senderName = 3;
 
- getSenderNameBytes() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
- 
optional string senderName = 3;
 
- getSenderNameBytes() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProtoOrBuilder
- 
optional string senderName = 3;
 
- getSequenceNumber() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenIdentifier
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
-  
- getSerializedSize() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
-  
- getSerializedSize() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto
-  
- getSerializedSize() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
-  
- getServer(Class<?>, Object, String, int, int, int, int, boolean, Configuration, SecretManager<? extends TokenIdentifier>, String, AlignmentContext) - Method in class org.apache.hadoop.ipc.ProtobufRpcEngine
-  
- getServer(Class<?>, Object, String, int, int, int, int, boolean, Configuration, SecretManager<? extends TokenIdentifier>, String, AlignmentContext) - Method in interface org.apache.hadoop.ipc.RpcEngine
- 
Construct a server for a protocol implementation instance. 
- getServer() - Method in class org.apache.hadoop.ipc.Server.Connection
-  
- getServer(Class<?>, Object, String, int, int, int, int, boolean, Configuration, SecretManager<? extends TokenIdentifier>, String, AlignmentContext) - Method in class org.apache.hadoop.ipc.WritableRpcEngine
-  
- getServerDefaults() - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
- getServerDefaults(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Return a set of server default configuration values based on path. 
- getServerDefaults() - Method in class org.apache.hadoop.fs.FileSystem
- 
- getServerDefaults(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Return a set of server default configuration values. 
- getServerDefaults() - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getServerDefaults(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getServerDefaults() - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getServerDefaults(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getServerDefaults() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getServerDefaults(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getServerDefaults() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
- 
Deprecated. 
- getServerDefaults(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getServerId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional string serverId = 4;
 
- getServerId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
optional string serverId = 4;
 
- getServerId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
optional string serverId = 4;
 
- getServerIdBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional string serverId = 4;
 
- getServerIdBytes() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
optional string serverId = 4;
 
- getServerIdBytes() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
optional string serverId = 4;
 
- getServerIpcVersionNum() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional uint32 serverIpcVersionNum = 3;
 
- getServerIpcVersionNum() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional uint32 serverIpcVersionNum = 3;
 
- getServerIpcVersionNum() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional uint32 serverIpcVersionNum = 3;
 
- getServerName() - Method in class org.apache.hadoop.http.HttpServer.QuotingInputFilter.RequestQuoter
- 
Deprecated. Quote the server name so that users specifying the HOST HTTP header
 can't inject attacks. 
- getServerName() - Method in class org.apache.hadoop.http.HttpServer2.QuotingInputFilter.RequestQuoter
- 
Quote the server name so that users specifying the HOST HTTP header
 can't inject attacks. 
- getServerPrincipal(String, String) - Static method in class org.apache.hadoop.security.SecurityUtil
- 
Convert Kerberos principal name pattern to valid Kerberos principal
 names. 
- getServerPrincipal(String, InetAddress) - Static method in class org.apache.hadoop.security.SecurityUtil
- 
Convert Kerberos principal name pattern to valid Kerberos principal names. 
- getServerProperties(InetAddress, int) - Method in class org.apache.hadoop.security.IngressPortBasedResolver
- 
Identify the Sasl Properties to be used for a connection with a client. 
- getServerProperties(InetAddress) - Method in class org.apache.hadoop.security.SaslPropertiesResolver
- 
Identify the Sasl Properties to be used for a connection with a  client. 
- getServerProperties(InetAddress, int) - Method in class org.apache.hadoop.security.SaslPropertiesResolver
- 
Identify the Sasl Properties to be used for a connection with a  client. 
- getServerProperties(InetAddress) - Method in class org.apache.hadoop.security.WhitelistBasedResolver
- 
Identify the Sasl Properties to be used for a connection with a client. 
- getServerProperties(String) - Method in class org.apache.hadoop.security.WhitelistBasedResolver
-  
- getServerVersion() - Method in exception org.apache.hadoop.ipc.RPC.VersionMismatch
- 
Get the server's agreed to version. 
- getService() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required string service = 4;
 
- getService() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
- 
required string service = 4;
 
- getService() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.TokenProtoOrBuilder
- 
required string service = 4;
 
- getService() - Method in class org.apache.hadoop.security.token.Token
- 
Get the service on which the token is supposed to be used 
- getService() - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Get the service. 
- getServiceBytes() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required string service = 4;
 
- getServiceBytes() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
- 
required string service = 4;
 
- getServiceBytes() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.TokenProtoOrBuilder
- 
required string service = 4;
 
- getServiceClass() - Method in class org.apache.hadoop.ipc.Server.Connection
- 
Get service class for connection 
- getServiceException() - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Get the exit exception used to end this service. 
- getServiceExitCode() - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
The exit code from a successful service execution. 
- getServiceName() - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
- getServices() - Method in class org.apache.hadoop.service.CompositeService
- 
Get a cloned list of services 
- getServiceState() - Method in class org.apache.hadoop.service.AbstractService
-  
- getServiceState() - Method in interface org.apache.hadoop.service.Service
- 
Get the current service state 
- getServiceStatus() - Method in interface org.apache.hadoop.ha.HAServiceProtocol
- 
Return the current status of the service. 
- getServiceStatus(RpcController, HAServiceProtocolProtos.GetServiceStatusRequestProto) - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService.BlockingInterface
-  
- getServiceStatus(RpcController, HAServiceProtocolProtos.GetServiceStatusRequestProto, RpcCallback<HAServiceProtocolProtos.GetServiceStatusResponseProto>) - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService
- 
rpc getServiceStatus(.hadoop.common.GetServiceStatusRequestProto) returns (.hadoop.common.GetServiceStatusResponseProto);
 
- getServiceStatus(RpcController, HAServiceProtocolProtos.GetServiceStatusRequestProto, RpcCallback<HAServiceProtocolProtos.GetServiceStatusResponseProto>) - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService.Interface
- 
rpc getServiceStatus(.hadoop.common.GetServiceStatusRequestProto) returns (.hadoop.common.GetServiceStatusResponseProto);
 
- getServiceStatus(RpcController, HAServiceProtocolProtos.GetServiceStatusRequestProto, RpcCallback<HAServiceProtocolProtos.GetServiceStatusResponseProto>) - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService.Stub
-  
- getSetOwnerCommand(String) - Static method in class org.apache.hadoop.util.Shell
- 
Return a command to set owner. 
- getSetPermissionCommand(String, boolean) - Static method in class org.apache.hadoop.util.Shell
- 
Return a command to set permission. 
- getSetPermissionCommand(String, boolean, String) - Static method in class org.apache.hadoop.util.Shell
- 
Return a command to set permission for specific file. 
- getShortUserName() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Get the user's login name. 
- getSignalKillCommand(int, String) - Static method in class org.apache.hadoop.util.Shell
- 
Return a command to send a signal to a given pid. 
- getSignature() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
- 
optional bytes signature = 2;
 
- getSignature() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
- 
optional bytes signature = 2;
 
- getSignature() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProtoOrBuilder
- 
optional bytes signature = 2;
 
- getSize() - Method in class org.apache.hadoop.io.BytesWritable
- 
- getSize() - Method in interface org.apache.hadoop.io.SequenceFile.ValueBytes
- 
Size of stored data. 
- getSlope(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
- 
Deprecated. 
- getSnapshotDirectoryCount() - Method in class org.apache.hadoop.fs.ContentSummary
-  
- getSnapshotFileCount() - Method in class org.apache.hadoop.fs.ContentSummary
-  
- getSnapshotLength() - Method in class org.apache.hadoop.fs.ContentSummary
-  
- getSnapshotSpaceConsumed() - Method in class org.apache.hadoop.fs.ContentSummary
-  
- getSnapshotTimeStamp() - Method in class org.apache.hadoop.metrics2.lib.MutableStat
- 
Return the SampleStat snapshot timestamp 
- getSocketAddr(String, String, String, int) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the socket address for hostPropertyas aInetSocketAddress.
 
- getSocketAddr(String, String, int) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the socket address for nameproperty as aInetSocketAddress.
 
- getSource() - Method in class org.apache.hadoop.ha.HAServiceProtocol.StateChangeRequestInfo
-  
- getSpaceConsumed() - Method in class org.apache.hadoop.fs.QuotaUsage
- 
Return (disk) space consumed. 
- getSpaceQuota() - Method in class org.apache.hadoop.fs.QuotaUsage
- 
Return (disk) space quota. 
- GetSpaceUsed - Interface in org.apache.hadoop.fs
-  
- GetSpaceUsed.Builder - Class in org.apache.hadoop.fs
- 
The builder class 
- GetSpaceUsed.Builder() - Constructor for class org.apache.hadoop.fs.GetSpaceUsed.Builder
-  
- getSrcChecksum() - Static method in class org.apache.hadoop.util.VersionInfo
- 
Get the checksum of the source files from which Hadoop was built. 
- getStackTrace() - Method in exception org.apache.hadoop.security.authorize.AuthorizationException
-  
- getStartTime() - Method in class org.apache.hadoop.conf.ReconfigurationTaskStatus
-  
- getStartTime() - Method in class org.apache.hadoop.fs.shell.find.FindOptions
- 
Returns the start time of this Findcommand.
 
- getStartTime() - Method in class org.apache.hadoop.service.AbstractService
-  
- getStartTime() - Method in interface org.apache.hadoop.service.Service
- 
Get the service start time 
- getState() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
- 
required .hadoop.common.HAServiceStateProto state = 1;
 
- getState() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
- 
required .hadoop.common.HAServiceStateProto state = 1;
 
- getState() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProtoOrBuilder
- 
required .hadoop.common.HAServiceStateProto state = 1;
 
- getState() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
required .hadoop.common.RpcSaslProto.SaslState state = 2;
 
- getState() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
required .hadoop.common.RpcSaslProto.SaslState state = 2;
 
- getState() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
required .hadoop.common.RpcSaslProto.SaslState state = 2;
 
- getState() - Method in class org.apache.hadoop.service.ServiceStateModel
- 
Query the service state. 
- getStateId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional int64 stateId = 8;
 
- getStateId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional int64 stateId = 8;
 
- getStateId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional int64 stateId = 8;
 
- getStateId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional int64 stateId = 9;
 
- getStateId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional int64 stateId = 9;
 
- getStateId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional int64 stateId = 9;
 
- getStatistics() - Method in class org.apache.hadoop.fs.AbstractFileSystem
-  
- getStatistics(URI) - Static method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Get the statistics for a particular file system. 
- getStatistics(URI) - Static method in class org.apache.hadoop.fs.FileContext
- 
Get the statistics for a particular file system 
- getStatistics() - Static method in class org.apache.hadoop.fs.FileSystem
- 
- getStatistics(String, Class<? extends FileSystem>) - Static method in class org.apache.hadoop.fs.FileSystem
- 
- getStats(int) - Method in interface org.apache.hadoop.log.LogThrottlingHelper.LogAction
- 
Return summary information for the value that was recorded at index
 idx.
 
- getStats(long) - Method in class org.apache.hadoop.metrics2.lib.MutableRollingAverages
- 
Retrieve a map of metric name -> (aggregate). 
- getStatus() - Method in class org.apache.hadoop.conf.ReconfigurationTaskStatus
-  
- getStatus() - Method in class org.apache.hadoop.fs.FileSystem
- 
Returns a status object describing the use and capacity of the
 filesystem. 
- getStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Returns a status object describing the use and capacity of the
 filesystem. 
- getStatus(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getStatus(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getStatus(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- getStatus() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
required .hadoop.common.RpcResponseHeaderProto.RpcStatusProto status = 2;
 
- getStatus() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
required .hadoop.common.RpcResponseHeaderProto.RpcStatusProto status = 2;
 
- getStatus() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
required .hadoop.common.RpcResponseHeaderProto.RpcStatusProto status = 2;
 
- getStickyBit() - Method in class org.apache.hadoop.fs.permission.FsPermission
-  
- getStorageBytesRead() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the aggregated number of bytes read from disks. 
- getStorageBytesWritten() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the aggregated number of bytes written to disks. 
- getStorageIds() - Method in class org.apache.hadoop.fs.BlockLocation
- 
Get the storageID of each replica of the block. 
- getStoragePolicy(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Retrieve the storage policy for a given file or directory. 
- getStoragePolicy(Path) - Method in class org.apache.hadoop.fs.FileContext
- 
Query the effective storage policy ID for the given file or directory. 
- getStoragePolicy(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Query the effective storage policy ID for the given file or directory. 
- getStoragePolicy(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getStoragePolicy(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
- 
Retrieve the storage policy for a given file or directory. 
- getStorageStatistics() - Method in class org.apache.hadoop.fs.FileSystem
- 
Get the StorageStatistics for this FileSystem object. 
- getStorageTypeHeader(List<StorageType>) - Static method in class org.apache.hadoop.fs.QuotaUsage
- 
return the header of with the StorageTypes. 
- getStorageTypes() - Method in class org.apache.hadoop.fs.BlockLocation
- 
Get the storage type of each replica of the block. 
- getStorageTypes() - Method in interface org.apache.hadoop.fs.BlockStoragePolicySpi
- 
Return the preferred storage types associated with this policy. 
- getString(String) - Method in class org.apache.hadoop.io.retry.FailoverProxyProvider.ProxyInfo
-  
- getStringCollection(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the comma delimited values of the nameproperty as 
 a collection ofStrings.
 
- getStrings(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the comma delimited values of the nameproperty as 
 an array ofStrings.
 
- getStrings(String, String...) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the comma delimited values of the nameproperty as 
 an array ofStrings.
 
- getSubject() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Get the underlying subject from this ugi. 
- GetSuffix(int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
- 
Deprecated. 
- getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.io.file.tfile.TFile
- 
Get names of supported compression algorithms. 
- getSwitchMap() - Method in class org.apache.hadoop.net.AbstractDNSToSwitchMapping
- 
Get a copy of the map (for diagnostics) 
- getSwitchMap() - Method in class org.apache.hadoop.net.CachedDNSToSwitchMapping
- 
Get the (host x switch) map. 
- getSymlink() - Method in class org.apache.hadoop.fs.FileStatus
-  
- getSymlinkCommand(String, String) - Static method in class org.apache.hadoop.util.Shell
- 
Return a command to create symbolic links. 
- getTabSize(int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
- 
Deprecated. 
- getTag(String) - Method in class org.apache.hadoop.metrics.spi.OutputRecord
- 
Deprecated. Returns a tag object which is can be a String, Integer, Short or Byte. 
- getTag(String) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
- 
Get a tag by name 
- getTag(String) - Method in class org.apache.hadoop.metrics2.util.MetricsCache.Record
- 
Lookup a tag value 
- getTagNames() - Method in class org.apache.hadoop.metrics.spi.OutputRecord
- 
Deprecated. Returns the set of tag names 
- getTagsCopy() - Method in class org.apache.hadoop.metrics.spi.OutputRecord
- 
Deprecated. Returns a copy of this record's tags. 
- getTargetFileSystemPaths() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem.MountPoint
-  
- getTargetPath() - Method in exception org.apache.hadoop.fs.PathIOException
-  
- getTestProvider() - Static method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
-  
- getThisBuilder() - Method in class org.apache.hadoop.fs.FSDataOutputStreamBuilder
- 
Return the concrete implementation of the builder instance. 
- getThreadStatistics() - Method in class org.apache.hadoop.fs.FileSystem.Statistics
- 
Get or create the thread-local data associated with the current thread. 
- getTicketCacheFile() - Method in exception org.apache.hadoop.security.KerberosAuthException
-  
- getTimeDuration(String, long, TimeUnit) - Method in class org.apache.hadoop.conf.Configuration
- 
Return time duration in the given time unit. 
- getTimeDuration(String, long, TimeUnit, TimeUnit) - Method in class org.apache.hadoop.conf.Configuration
- 
Return time duration in the given time unit. 
- getTimeDurations(String, TimeUnit) - Method in class org.apache.hadoop.conf.Configuration
-  
- getTimeout(Configuration) - Static method in class org.apache.hadoop.ipc.Client
- 
- getTimeout() - Method in class org.apache.hadoop.security.ShellBasedIdMapping
-  
- getTimeoutInterval() - Method in class org.apache.hadoop.util.Shell.ShellCommandExecutor
- 
Returns the timeout value set for the executor's sub-commands. 
- getTimerTask() - Method in class org.apache.hadoop.util.NodeHealthScriptRunner
- 
Used only by tests to access the timer task directly 
- getTimestamp() - Method in class org.apache.hadoop.util.GcTimeMonitor.GcData
- 
Returns the absolute timestamp when this measurement was taken. 
- getTmax(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
- 
Deprecated. 
- getToken() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
optional bytes token = 3;
 
- getToken() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
optional bytes token = 3;
 
- getToken() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
optional bytes token = 3;
 
- getToken(int) - Method in class org.apache.hadoop.record.compiler.generated.Rcc
- 
Deprecated. 
- getToken(Text) - Method in class org.apache.hadoop.security.Credentials
- 
Returns the Token object for the alias 
- getToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto.Builder
- 
required .hadoop.common.TokenProto token = 1;
 
- getToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto
- 
required .hadoop.common.TokenProto token = 1;
 
- getToken() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProtoOrBuilder
- 
required .hadoop.common.TokenProto token = 1;
 
- getToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto.Builder
- 
optional .hadoop.common.TokenProto token = 1;
 
- getToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto
- 
optional .hadoop.common.TokenProto token = 1;
 
- getToken() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProtoOrBuilder
- 
optional .hadoop.common.TokenProto token = 1;
 
- getToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto.Builder
- 
required .hadoop.common.TokenProto token = 1;
 
- getToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto
- 
required .hadoop.common.TokenProto token = 1;
 
- getToken() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProtoOrBuilder
- 
required .hadoop.common.TokenProto token = 1;
 
- getTokenBuilder() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto.Builder
- 
required .hadoop.common.TokenProto token = 1;
 
- getTokenBuilder() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto.Builder
- 
optional .hadoop.common.TokenProto token = 1;
 
- getTokenBuilder() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto.Builder
- 
required .hadoop.common.TokenProto token = 1;
 
- getTokenIdentifiers() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Get the set of TokenIdentifiers belonging to this UGI 
- getTokenInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.security.AnnotatedSecurityInfo
-  
- getTokenInfo(Class<?>, Configuration) - Static method in class org.apache.hadoop.security.SecurityUtil
- 
Look up the TokenInfo for a given protocol. 
- getTokenInfo(TokenIdent) - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
- 
For subclasses externalizing the storage, for example Zookeeper
 based implementations 
- getTokenOrBuilder() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto.Builder
- 
required .hadoop.common.TokenProto token = 1;
 
- getTokenOrBuilder() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto
- 
required .hadoop.common.TokenProto token = 1;
 
- getTokenOrBuilder() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProtoOrBuilder
- 
required .hadoop.common.TokenProto token = 1;
 
- getTokenOrBuilder() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto.Builder
- 
optional .hadoop.common.TokenProto token = 1;
 
- getTokenOrBuilder() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto
- 
optional .hadoop.common.TokenProto token = 1;
 
- getTokenOrBuilder() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProtoOrBuilder
- 
optional .hadoop.common.TokenProto token = 1;
 
- getTokenOrBuilder() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto.Builder
- 
required .hadoop.common.TokenProto token = 1;
 
- getTokenOrBuilder() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto
- 
required .hadoop.common.TokenProto token = 1;
 
- getTokenOrBuilder() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProtoOrBuilder
- 
required .hadoop.common.TokenProto token = 1;
 
- getTokens() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Obtain the collection of tokens associated with this user. 
- getTokenServiceAddr(Token<?>) - Static method in class org.apache.hadoop.security.SecurityUtil
- 
Decode the given token's service field into an InetAddress 
- getTokenTrackingId(TokenIdent) - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
-  
- getTopologyPaths() - Method in class org.apache.hadoop.fs.BlockLocation
- 
Get the list of network topology paths for each of the hosts. 
- getTotalCallVolume() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler
-  
- getTotalCallVolume() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler.MetricsProxy
-  
- getTotalCallVolume() - Method in interface org.apache.hadoop.ipc.DecayRpcSchedulerMXBean
-  
- getTotalRawCallVolume() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler
-  
- getTraceId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
- 
optional int64 traceId = 1;
 
- getTraceId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
- 
optional int64 traceId = 1;
 
- getTraceId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProtoOrBuilder
- 
optional int64 traceId = 1;
 
- getTraceInfo() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- getTraceInfo() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- getTraceInfo() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- getTraceInfoBuilder() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- getTraceInfoOrBuilder() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- getTraceInfoOrBuilder() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- getTraceInfoOrBuilder() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- getTrackingId() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager.DelegationTokenInformation
- 
returns tracking id 
- getTrackingId() - Method in class org.apache.hadoop.security.token.TokenIdentifier
- 
Returns a tracking identifier that can be used to associate usages of a
 token across multiple client sessions. 
- getTrackingIdIfEnabled(TokenIdent) - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenSecretManager
-  
- getTransitionTargetHAStatus() - Method in class org.apache.hadoop.ha.HAServiceTarget
-  
- getTrashCanLocation(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getTrashInterval() - Method in class org.apache.hadoop.fs.FsServerDefaults
-  
- getTrashRoot(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Get the root directory of Trash for current user when the path specified
 is deleted. 
- getTrashRoot(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getTrashRoot(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
- 
Get the trash root directory for current user when the path
 specified is deleted. 
- getTrashRoots(boolean) - Method in class org.apache.hadoop.fs.FileSystem
- 
Get all the trash roots for current user or all users. 
- getTrashRoots(boolean) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getTrashRoots(boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
- 
Get all the trash roots for current user or all users. 
- getTrimmed(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as a trimmedString,nullif no such property exists.
 
- getTrimmed(String, String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the value of the nameproperty as a trimmedString,defaultValueif no such property exists.
 
- getTrimmedStringCollection(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the comma delimited values of the nameproperty as 
 a collection ofStrings, trimmed of the leading and trailing whitespace.
 
- getTrimmedStrings(String) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the comma delimited values of the nameproperty as 
 an array ofStrings, trimmed of the leading and trailing whitespace.
 
- getTrimmedStrings(String, String...) - Method in class org.apache.hadoop.conf.Configuration
- 
Get the comma delimited values of the nameproperty as 
 an array ofStrings, trimmed of the leading and trailing whitespace.
 
- getType() - Method in class org.apache.hadoop.fs.permission.AclEntry
- 
Returns the ACL entry type. 
- getTypeConsumed(StorageType) - Method in class org.apache.hadoop.fs.QuotaUsage
- 
Return storage type consumed. 
- getTypeID() - Method in class org.apache.hadoop.record.meta.FieldTypeInfo
- 
Deprecated. get the field's TypeID object 
- getTypeQuota(StorageType) - Method in class org.apache.hadoop.fs.QuotaUsage
- 
Return storage type quota. 
- getTypes() - Method in class org.apache.hadoop.io.GenericWritable
- 
Return all classes that may be wrapped. 
- getTypesQuotaUsage(boolean, List<StorageType>) - Method in class org.apache.hadoop.fs.QuotaUsage
-  
- getTypesSupportingQuota() - Static method in enum org.apache.hadoop.fs.StorageType
-  
- getTypeVal() - Method in class org.apache.hadoop.record.meta.TypeID
- 
Deprecated. Get the type value. 
- getUgi() - Method in class org.apache.hadoop.fs.FileContext
- 
Gets the ugi in the file-context 
- getUgi(IpcConnectionContextProtos.IpcConnectionContextProto) - Static method in class org.apache.hadoop.util.ProtoUtil
-  
- getUgi(IpcConnectionContextProtos.UserInformationProto) - Static method in class org.apache.hadoop.util.ProtoUtil
-  
- getUGIFromSubject(Subject) - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Create a UserGroupInformation from a Subject with Kerberos principal. 
- getUGIFromTicketCache(String, String) - Static method in class org.apache.hadoop.security.UserGroupInformation
- 
Create a UserGroupInformation from a Kerberos ticket cache. 
- getUgmProtocol() - Method in class org.apache.hadoop.tools.GetGroupsBase
- 
Get a client of the GetUserMappingsProtocol.
 
- getUid(String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
-  
- getUid(String) - Method in class org.apache.hadoop.security.ShellBasedIdMapping
-  
- getUidAllowingUnknown(String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
-  
- getUidAllowingUnknown(String) - Method in class org.apache.hadoop.security.ShellBasedIdMapping
-  
- getUidNameMap() - Method in class org.apache.hadoop.security.ShellBasedIdMapping
-  
- getUMask() - Method in class org.apache.hadoop.fs.FileContext
-  
- getUMask(Configuration) - Static method in class org.apache.hadoop.fs.permission.FsPermission
- 
Get the user file creation mask (umask)
 
 UMASK_LABELconfig param has umask value that is either symbolic 
 or octal.
 
- getUnderlyingProxyObject() - Method in class org.apache.hadoop.ha.protocolPB.ZKFCProtocolClientSideTranslatorPB
-  
- getUniqueIdentityCount() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler
-  
- getUniqueIdentityCount() - Method in class org.apache.hadoop.ipc.DecayRpcScheduler.MetricsProxy
-  
- getUniqueIdentityCount() - Method in interface org.apache.hadoop.ipc.DecayRpcSchedulerMXBean
-  
- getUnits(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
- 
Deprecated. 
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
-  
- getUnknownFields() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
-  
- getUnknownFields() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto
-  
- getUnknownFields() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
-  
- getUri() - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Returns a URI whose scheme and authority identify this FileSystem. 
- getUri() - Method in class org.apache.hadoop.fs.FileSystem
- 
Returns a URI which identifies this FileSystem. 
- getUri() - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
Returns a URI whose scheme and authority identify this FileSystem. 
- getUri() - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
-  
- getUri() - Method in class org.apache.hadoop.fs.HarFileSystem
- 
Returns the uri of this filesystem. 
- getUri() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- getUri() - Method in class org.apache.hadoop.fs.sftp.SFTPFileSystem
-  
- getUri() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getUriDefaultPort() - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
The default port of this file system. 
- getUriDefaultPort() - Method in class org.apache.hadoop.fs.HarFs
-  
- getUriDefaultPort() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getUriPath(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Get the path-part of a pathname. 
- getUrl() - Static method in class org.apache.hadoop.util.VersionInfo
- 
Get the URL for the Hadoop repository. 
- getUsage() - Method in class org.apache.hadoop.fs.DUHelper
-  
- getUsage() - Method in class org.apache.hadoop.fs.shell.find.BaseExpression
-  
- getUsage() - Method in interface org.apache.hadoop.fs.shell.find.Expression
- 
Returns brief usage instructions for this expression. 
- getUsage() - Method in class org.apache.hadoop.fs.shell.find.FilterExpression
-  
- getUsageMessage() - Method in class org.apache.hadoop.service.launcher.ServiceLauncher
- 
Get the usage message, ideally dynamically. 
- getUsed() - Method in class org.apache.hadoop.fs.FileSystem
- 
Return the total size of all files in the filesystem. 
- getUsed(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Return the total size of all files from a specified path. 
- getUsed() - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
Return the total size of all files in the filesystem. 
- getUsed(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
Return the total size of all files from a specified path. 
- getUsed() - Method in class org.apache.hadoop.fs.FsStatus
- 
Return the number of bytes used on the file system 
- getUsed() - Method in interface org.apache.hadoop.fs.GetSpaceUsed
-  
- getUsed() - Method in class org.apache.hadoop.fs.HarFileSystem
-  
- getUsed(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
- 
Return the total size of all files from a specified path. 
- getUser() - Method in exception org.apache.hadoop.security.KerberosAuthException
-  
- getUser() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenIdentifier
- 
Get the username encoded in the token identifier 
- getUser() - Method in class org.apache.hadoop.security.token.TokenIdentifier
- 
Get the Ugi with the username encoded in the token identifier 
- getUser() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto.Builder
- 
required string user = 1;
 
- getUser() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto
- 
required string user = 1;
 
- getUser() - Method in interface org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProtoOrBuilder
- 
required string user = 1;
 
- getUser() - Static method in class org.apache.hadoop.util.VersionInfo
- 
The user that compiled Hadoop. 
- getUserAction() - Method in class org.apache.hadoop.fs.permission.FsPermission
- 
- getUserBytes() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto.Builder
- 
required string user = 1;
 
- getUserBytes() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto
- 
required string user = 1;
 
- getUserBytes() - Method in interface org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProtoOrBuilder
- 
required string user = 1;
 
- getUserGroupInformation() - Method in class org.apache.hadoop.ipc.Server.Call
-  
- getUserInfo() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- getUserInfo() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- getUserInfo() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProtoOrBuilder
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- getUserInfoBuilder() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProtoOrBuilder
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- GetUserMappingsProtocolClientSideTranslatorPB - Class in org.apache.hadoop.tools.protocolPB
-  
- GetUserMappingsProtocolClientSideTranslatorPB(GetUserMappingsProtocolPB) - Constructor for class org.apache.hadoop.tools.protocolPB.GetUserMappingsProtocolClientSideTranslatorPB
-  
- GetUserMappingsProtocolProtos - Class in org.apache.hadoop.tools.proto
-  
- GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto - Class in org.apache.hadoop.tools.proto
- 
Protobuf type hadoop.common.GetGroupsForUserRequestProto
 
- GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto.Builder - Class in org.apache.hadoop.tools.proto
- 
Protobuf type hadoop.common.GetGroupsForUserRequestProto
 
- GetUserMappingsProtocolProtos.GetGroupsForUserRequestProtoOrBuilder - Interface in org.apache.hadoop.tools.proto
-  
- GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto - Class in org.apache.hadoop.tools.proto
- 
Protobuf type hadoop.common.GetGroupsForUserResponseProto
 
- GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto.Builder - Class in org.apache.hadoop.tools.proto
- 
Protobuf type hadoop.common.GetGroupsForUserResponseProto
 
- GetUserMappingsProtocolProtos.GetGroupsForUserResponseProtoOrBuilder - Interface in org.apache.hadoop.tools.proto
-  
- GetUserMappingsProtocolProtos.GetUserMappingsProtocolService - Class in org.apache.hadoop.tools.proto
- 
Protobuf service hadoop.common.GetUserMappingsProtocolService
 
- GetUserMappingsProtocolProtos.GetUserMappingsProtocolService() - Constructor for class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetUserMappingsProtocolService
-  
- GetUserMappingsProtocolProtos.GetUserMappingsProtocolService.BlockingInterface - Interface in org.apache.hadoop.tools.proto
-  
- GetUserMappingsProtocolProtos.GetUserMappingsProtocolService.Interface - Interface in org.apache.hadoop.tools.proto
-  
- GetUserMappingsProtocolProtos.GetUserMappingsProtocolService.Stub - Class in org.apache.hadoop.tools.proto
-  
- GetUserMappingsProtocolServerSideTranslatorPB - Class in org.apache.hadoop.tools.protocolPB
-  
- GetUserMappingsProtocolServerSideTranslatorPB(GetUserMappingsProtocol) - Constructor for class org.apache.hadoop.tools.protocolPB.GetUserMappingsProtocolServerSideTranslatorPB
-  
- getUserMessage() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional string userMessage = 2;
 
- getUserMessage() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
- 
optional string userMessage = 2;
 
- getUserMessage() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProtoOrBuilder
- 
optional string userMessage = 2;
 
- getUserMessageBytes() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional string userMessage = 2;
 
- getUserMessageBytes() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
- 
optional string userMessage = 2;
 
- getUserMessageBytes() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProtoOrBuilder
- 
optional string userMessage = 2;
 
- getUserName(int, String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
-  
- getUserName(int, String) - Method in class org.apache.hadoop.security.ShellBasedIdMapping
-  
- getUserName() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Get the user's full principal name. 
- getUsers() - Method in class org.apache.hadoop.security.authorize.AccessControlList
- 
Get the names of users allowed for this service. 
- getUsersForNetgroupCommand(String) - Static method in class org.apache.hadoop.util.Shell
- 
A command to get a given netgroup's user list. 
- getVal() - Method in class org.apache.hadoop.util.Waitable
-  
- getValByRegex(String) - Method in class org.apache.hadoop.conf.Configuration
- 
get keys matching the the regex 
- getValue() - Method in class org.apache.hadoop.fs.Options.CreateOpts.BlockSize
-  
- getValue() - Method in class org.apache.hadoop.fs.Options.CreateOpts.BufferSize
-  
- getValue() - Method in class org.apache.hadoop.fs.Options.CreateOpts.BytesPerChecksum
-  
- getValue() - Method in class org.apache.hadoop.fs.Options.CreateOpts.ChecksumParam
-  
- getValue() - Method in class org.apache.hadoop.fs.Options.CreateOpts.CreateParent
-  
- getValue() - Method in class org.apache.hadoop.fs.Options.CreateOpts.Perms
-  
- getValue() - Method in class org.apache.hadoop.fs.Options.CreateOpts.Progress
-  
- getValue() - Method in class org.apache.hadoop.fs.Options.CreateOpts.ReplicationFactor
-  
- getValue() - Method in class org.apache.hadoop.fs.StorageStatistics.LongStatistic
-  
- getValue() - Method in enum org.apache.hadoop.fs.StreamCapabilities.StreamCapability
- 
Deprecated. 
- getValue(BytesWritable) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Copy the value into BytesWritable. 
- getValue(byte[]) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Copy value into user-supplied buffer. 
- getValue(byte[], int) - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Copy value into user-supplied buffer. 
- getValue() - Method in interface org.apache.hadoop.io.SequenceFile.Sorter.RawKeyValueIterator
- 
Gets the current raw value 
- getValue(T) - Method in class org.apache.hadoop.ipc.RpcWritable.Buffer
-  
- getValue() - Method in enum org.apache.hadoop.service.Service.STATE
- 
Get the integer value of a state 
- getValue() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
- 
required string value = 2;
 
- getValue() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
- 
required string value = 2;
 
- getValue() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ConfigPairOrBuilder
- 
required string value = 2;
 
- getValue() - Method in class org.apache.hadoop.util.Options.BooleanOption
-  
- getValue() - Method in class org.apache.hadoop.util.Options.ClassOption
-  
- getValue() - Method in class org.apache.hadoop.util.Options.FSDataInputStreamOption
-  
- getValue() - Method in class org.apache.hadoop.util.Options.FSDataOutputStreamOption
-  
- getValue() - Method in class org.apache.hadoop.util.Options.IntegerOption
-  
- getValue() - Method in class org.apache.hadoop.util.Options.LongOption
-  
- getValue() - Method in class org.apache.hadoop.util.Options.PathOption
-  
- getValue() - Method in class org.apache.hadoop.util.Options.ProgressableOption
-  
- getValue() - Method in class org.apache.hadoop.util.Options.StringOption
-  
- getValue() - Method in class org.apache.hadoop.util.PureJavaCrc32
-  
- getValue() - Method in class org.apache.hadoop.util.PureJavaCrc32C
-  
- getValueBytes() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
- 
required string value = 2;
 
- getValueBytes() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
- 
required string value = 2;
 
- getValueBytes() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ConfigPairOrBuilder
- 
required string value = 2;
 
- getValueClass() - Method in class org.apache.hadoop.io.ArrayWritable
-  
- getValueClass() - Method in class org.apache.hadoop.io.MapFile.Reader
- 
Returns the class of values in this file. 
- getValueClass() - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Returns the class of values in this file. 
- getValueClass() - Method in class org.apache.hadoop.io.SequenceFile.Writer
- 
Returns the class of values in this file. 
- getValueClassName() - Method in class org.apache.hadoop.io.SequenceFile.Reader
- 
Returns the name of the value class. 
- getValueDescriptor() - Method in enum org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HARequestSource
-  
- getValueDescriptor() - Method in enum org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceStateProto
-  
- getValueDescriptor() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcKindProto
-  
- getValueDescriptor() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.OperationProto
-  
- getValueDescriptor() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.RpcErrorCodeProto
-  
- getValueDescriptor() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.RpcStatusProto
-  
- getValueDescriptor() - Method in enum org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslState
-  
- getValueLength() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Get the length of the value. 
- getValueStream() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
- 
Stream access to value. 
- getValueTypeID() - Method in class org.apache.hadoop.record.meta.MapTypeID
- 
Deprecated. get the TypeID of the map's value element 
- getVectorSize() - Method in class org.apache.hadoop.util.bloom.BloomFilter
-  
- getVersion() - Method in class org.apache.hadoop.io.VersionedWritable
- 
Return the version number of the current implementation. 
- getVersion() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
- 
required uint64 version = 1;
 
- getVersion() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
- 
required uint64 version = 1;
 
- getVersion() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProtoOrBuilder
- 
required uint64 version = 1;
 
- getVersion() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
optional uint32 version = 1;
 
- getVersion() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
optional uint32 version = 1;
 
- getVersion() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
optional uint32 version = 1;
 
- getVersion() - Method in class org.apache.hadoop.ipc.ProtocolSignature
-  
- getVersion() - Static method in class org.apache.hadoop.util.VersionInfo
- 
Get the Hadoop version. 
- getVersionName() - Method in class org.apache.hadoop.crypto.key.KeyProvider.KeyVersion
-  
- getVersions() - Method in class org.apache.hadoop.crypto.key.KeyProvider.Metadata
-  
- getVersions(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
- 
repeated uint64 versions = 2;
 
- getVersions(int) - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
- 
repeated uint64 versions = 2;
 
- getVersions(int) - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProtoOrBuilder
- 
repeated uint64 versions = 2;
 
- getVersionsCount() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
- 
repeated uint64 versions = 2;
 
- getVersionsCount() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
- 
repeated uint64 versions = 2;
 
- getVersionsCount() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProtoOrBuilder
- 
repeated uint64 versions = 2;
 
- getVersionsList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
- 
repeated uint64 versions = 2;
 
- getVersionsList() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
- 
repeated uint64 versions = 2;
 
- getVersionsList() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProtoOrBuilder
- 
repeated uint64 versions = 2;
 
- getVIntSize(long) - Static method in class org.apache.hadoop.io.WritableUtils
- 
Get the encoded length if an integer is stored in a variable-length format 
- getVIntSize(long) - Static method in class org.apache.hadoop.record.Utils
- 
Deprecated. Get the encoded length if an integer is stored in a variable-length format 
- getVirtualMemorySize() - Method in class org.apache.hadoop.util.SysInfo
- 
Obtain the total size of the virtual memory present in the system. 
- getWaitingThread() - Method in class org.apache.hadoop.util.Shell
- 
get the thread that is waiting on this instance of Shell.
 
- getWinUtilsFile() - Static method in class org.apache.hadoop.util.Shell
- 
Get a file reference to winutils. 
- getWinUtilsPath() - Static method in class org.apache.hadoop.util.Shell
- 
Locate the winutils binary, or fail with a meaningful
 exception and stack trace as an RTE. 
- getWorkFactor(Configuration) - Static method in class org.apache.hadoop.io.compress.bzip2.Bzip2Factory
-  
- getWorkingDirectory() - Method in class org.apache.hadoop.fs.FileContext
- 
Gets the working directory for wd-relative names (such a "foo/bar"). 
- getWorkingDirectory() - Method in class org.apache.hadoop.fs.FileSystem
- 
Get the current working directory for the given FileSystem 
- getWorkingDirectory() - Method in class org.apache.hadoop.fs.FilterFileSystem
- 
Get the current working directory for the given file system 
- getWorkingDirectory() - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
-  
- getWorkingDirectory() - Method in class org.apache.hadoop.fs.HarFileSystem
- 
return the top level archive. 
- getWorkingDirectory() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- getWorkingDirectory() - Method in class org.apache.hadoop.fs.sftp.SFTPFileSystem
-  
- getWorkingDirectory() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getWriteOps() - Method in class org.apache.hadoop.fs.FileSystem.Statistics
- 
Get the number of file system write operations such as create, append
 rename etc. 
- getWriteOps() - Method in class org.apache.hadoop.fs.FileSystem.Statistics.StatisticsData
-  
- getWritePacketSize() - Method in class org.apache.hadoop.fs.FsServerDefaults
-  
- getXAttr(Path, String) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Get an xattr for a file or directory. 
- getXAttr(Path, String) - Method in class org.apache.hadoop.fs.FileContext
- 
Get an xattr for a file or directory. 
- getXAttr(Path, String) - Method in class org.apache.hadoop.fs.FileSystem
- 
Get an xattr name and value for a file or directory. 
- getXAttr(Path, String) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getXAttr(Path, String) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getXAttr(Path, String) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getXAttrs(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Get all of the xattrs for a file or directory. 
- getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.AbstractFileSystem
- 
Get all of the xattrs for a file or directory. 
- getXAttrs(Path) - Method in class org.apache.hadoop.fs.FileContext
- 
Get all of the xattrs for a file or directory. 
- getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.FileContext
- 
Get all of the xattrs for a file or directory. 
- getXAttrs(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Get all of the xattr name/value pairs for a file or directory. 
- getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.FileSystem
- 
Get all of the xattrs name/value pairs for a file or directory. 
- getXAttrs(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.FilterFileSystem
-  
- getXAttrs(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
-  
- getXAttrs(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
-  
- getZKFCAddress() - Method in class org.apache.hadoop.ha.HAServiceTarget
-  
- getZKFCProxy(Configuration, int) - Method in class org.apache.hadoop.ha.HAServiceTarget
-  
- getZlibCompressor(Configuration) - Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
- 
Return the appropriate implementation of the zlib compressor. 
- getZlibCompressorType(Configuration) - Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
- 
Return the appropriate type of the zlib compressor. 
- getZlibDecompressor(Configuration) - Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
- 
Return the appropriate implementation of the zlib decompressor. 
- getZlibDecompressorType(Configuration) - Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
- 
Return the appropriate type of the zlib decompressor. 
- getZlibDirectDecompressor(Configuration) - Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
- 
Return the appropriate implementation of the zlib direct decompressor. 
- GlobalStorageStatistics - Enum in org.apache.hadoop.fs
- 
Stores global storage statistics objects. 
- GlobalStorageStatistics.StorageStatisticsProvider - Interface in org.apache.hadoop.fs
- 
A callback API for creating new StorageStatistics instances. 
- GlobFilter - Class in org.apache.hadoop.fs
- 
A filter for POSIX glob pattern with brace expansions. 
- GlobFilter(String) - Constructor for class org.apache.hadoop.fs.GlobFilter
- 
Creates a glob filter with the specified file pattern. 
- GlobFilter(String, PathFilter) - Constructor for class org.apache.hadoop.fs.GlobFilter
- 
Creates a glob filter with the specified file pattern and an user filter. 
- GlobFilter - Class in org.apache.hadoop.metrics2.filter
- 
A glob pattern filter for metrics. 
- GlobFilter() - Constructor for class org.apache.hadoop.metrics2.filter.GlobFilter
-  
- globStatus(Path) - Method in class org.apache.hadoop.fs.FileContext.Util
- 
Return all the files that match filePattern and are not checksum
 files. 
- globStatus(Path, PathFilter) - Method in class org.apache.hadoop.fs.FileContext.Util
- 
Return an array of FileStatus objects whose path names match pathPattern
 and is accepted by the user-supplied path filter. 
- globStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
- 
Return all the files that match filePattern and are not checksum
 files. 
- globStatus(Path, PathFilter) - Method in class org.apache.hadoop.fs.FileSystem
- 
Return an array of  FileStatus objects whose path names match
  pathPattern
 and is accepted by the user-supplied path filter. 
- gracefulFailover(RpcController, ZKFCProtocolProtos.GracefulFailoverRequestProto) - Method in interface org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService.BlockingInterface
-  
- gracefulFailover(RpcController, ZKFCProtocolProtos.GracefulFailoverRequestProto, RpcCallback<ZKFCProtocolProtos.GracefulFailoverResponseProto>) - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService
- 
rpc gracefulFailover(.hadoop.common.GracefulFailoverRequestProto) returns (.hadoop.common.GracefulFailoverResponseProto);
 
- gracefulFailover(RpcController, ZKFCProtocolProtos.GracefulFailoverRequestProto, RpcCallback<ZKFCProtocolProtos.GracefulFailoverResponseProto>) - Method in interface org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService.Interface
- 
rpc gracefulFailover(.hadoop.common.GracefulFailoverRequestProto) returns (.hadoop.common.GracefulFailoverResponseProto);
 
- gracefulFailover(RpcController, ZKFCProtocolProtos.GracefulFailoverRequestProto, RpcCallback<ZKFCProtocolProtos.GracefulFailoverResponseProto>) - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.ZKFCProtocolService.Stub
-  
- gracefulFailover() - Method in class org.apache.hadoop.ha.protocolPB.ZKFCProtocolClientSideTranslatorPB
-  
- GraphiteSink - Class in org.apache.hadoop.metrics2.sink
- 
A metrics sink that writes to a Graphite server 
- GraphiteSink() - Constructor for class org.apache.hadoop.metrics2.sink.GraphiteSink
-  
- GraphiteSink.Graphite - Class in org.apache.hadoop.metrics2.sink
-  
- GraphiteSink.Graphite(String, int) - Constructor for class org.apache.hadoop.metrics2.sink.GraphiteSink.Graphite
-  
- GREATER_ICOST - Static variable in class org.apache.hadoop.io.compress.bzip2.CBZip2OutputStream
- 
This constant is accessible by subclasses for historical purposes. 
- group - Variable in class org.apache.hadoop.fs.FsShellPermissions.Chown
-  
- group(String) - Method in class org.apache.hadoop.fs.permission.AclStatus.Builder
- 
Sets the file group. 
- GROUP_MAPPING_CONFIG_PREFIX - Static variable in interface org.apache.hadoop.security.GroupMappingServiceProvider
-  
- GroupMappingServiceProvider - Interface in org.apache.hadoop.security
- 
An interface for the implementation of a user-to-groups mapping service
 used by Groups.
 
- GROUPS_FIELD_NUMBER - Static variable in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
-  
- GT_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
- 
Deprecated. 
- GzipCodec - Class in org.apache.hadoop.io.compress
- 
This class creates gzip compressors/decompressors. 
- GzipCodec() - Constructor for class org.apache.hadoop.io.compress.GzipCodec
-  
- GzipCodec.GzipOutputStream - Class in org.apache.hadoop.io.compress
- 
A bridge that wraps around a DeflaterOutputStream to make it 
 a CompressionOutputStream. 
- GzipCodec.GzipOutputStream(OutputStream) - Constructor for class org.apache.hadoop.io.compress.GzipCodec.GzipOutputStream
-  
- GzipCodec.GzipOutputStream(CompressorStream) - Constructor for class org.apache.hadoop.io.compress.GzipCodec.GzipOutputStream
- 
Allow children types to put a different type in here. 
- HAAdmin.UsageInfo - Class in org.apache.hadoop.ha
-  
- HAAdmin.UsageInfo(String, String) - Constructor for class org.apache.hadoop.ha.HAAdmin.UsageInfo
-  
- HADOOP_AUTHENTICATION_IS_DISABLED - Static variable in class org.apache.hadoop.security.KDiag
-  
- HADOOP_CALLER_CONTEXT_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_CALLER_CONTEXT_ENABLED_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_CALLER_CONTEXT_MAX_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_CALLER_CONTEXT_MAX_SIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_CALLER_CONTEXT_SIGNATURE_MAX_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_CALLER_CONTEXT_SIGNATURE_MAX_SIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_HTTP_AUTHENTICATION_TYPE - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_HTTP_LOGS_ENABLED - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_HTTP_LOGS_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Defalt value for HADOOP_HTTP_LOGS_ENABLED 
- HADOOP_JAAS_DEBUG - Static variable in class org.apache.hadoop.security.KDiag
-  
- HADOOP_KERBEROS_MIN_SECONDS_BEFORE_RELOGIN - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
- HADOOP_KERBEROS_MIN_SECONDS_BEFORE_RELOGIN_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Default value for HADOOP_KERBEROS_MIN_SECONDS_BEFORE_RELOGIN 
- HADOOP_RPC_PROTECTION - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_RPC_PROTECTION_NON_WHITELIST - Static variable in class org.apache.hadoop.security.WhitelistBasedResolver
- 
comma separated list containing alternate hadoop.rpc.protection values for
 clients which are not in whitelist 
- HADOOP_RPC_SOCKET_FACTORY_CLASS_DEFAULT_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_RPC_SOCKET_FACTORY_CLASS_DEFAULT_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_AUTH_TO_LOCAL - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_AUTHENTICATION - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_AUTHORIZATION - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CREDENTIAL_CLEAR_TEXT_FALLBACK - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CREDENTIAL_CLEAR_TEXT_FALLBACK_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CREDENTIAL_PASSWORD_FILE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CREDENTIAL_PROVIDER_PATH - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CRYPTO_BUFFER_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Defalt value for HADOOP_SECURITY_CRYPTO_BUFFER_SIZE_KEY 
- HADOOP_SECURITY_CRYPTO_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CRYPTO_CIPHER_SUITE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CRYPTO_CIPHER_SUITE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CRYPTO_CODEC_CLASSES_AES_CTR_NOPADDING_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CRYPTO_CODEC_CLASSES_AES_CTR_NOPADDING_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CRYPTO_CODEC_CLASSES_KEY_PREFIX - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CRYPTO_JCE_PROVIDER_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_CRYPTO_JCEKS_KEY_SERIALFILTER - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_DNS_INTERFACE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_DNS_NAMESERVER_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUP_MAPPING - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUP_SHELL_COMMAND_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUP_SHELL_COMMAND_TIMEOUT_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUP_SHELL_COMMAND_TIMEOUT_SECS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
- HADOOP_SECURITY_GROUP_SHELL_COMMAND_TIMEOUT_SECS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
- HADOOP_SECURITY_GROUPS_CACHE_BACKGROUND_RELOAD - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUPS_CACHE_BACKGROUND_RELOAD_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUPS_CACHE_BACKGROUND_RELOAD_THREADS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUPS_CACHE_BACKGROUND_RELOAD_THREADS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUPS_CACHE_SECS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUPS_CACHE_SECS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUPS_CACHE_WARN_AFTER_MS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUPS_CACHE_WARN_AFTER_MS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUPS_NEGATIVE_CACHE_SECS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_GROUPS_NEGATIVE_CACHE_SECS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_IMPERSONATION_PROVIDER_CLASS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Class to override Impersonation provider 
- HADOOP_SECURITY_INSTRUMENTATION_REQUIRES_ADMIN - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_JAVA_SECURE_RANDOM_ALGORITHM_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Defalt value for HADOOP_SECURITY_JAVA_SECURE_RANDOM_ALGORITHM_KEY 
- HADOOP_SECURITY_JAVA_SECURE_RANDOM_ALGORITHM_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_KEY_DEFAULT_BITLENGTH_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Defalt value for HADOOP_SECURITY_KEY_DEFAULT_BITLENGTH_KEY. 
- HADOOP_SECURITY_KEY_DEFAULT_BITLENGTH_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_KEY_DEFAULT_CIPHER_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Defalt value for HADOOP_SECURITY_KEY_DEFAULT_CIPHER_KEY. 
- HADOOP_SECURITY_KEY_DEFAULT_CIPHER_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_KEY_PROVIDER_PATH - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_SASL_FIXEDWHITELIST_FILE - Static variable in class org.apache.hadoop.security.WhitelistBasedResolver
- 
Path to the file to containing subnets and ip addresses to form fixed whitelist. 
- HADOOP_SECURITY_SASL_PROPS_RESOLVER_CLASS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Class to override Sasl Properties for a connection 
- HADOOP_SECURITY_SASL_VARIABLEWHITELIST_CACHE_SECS - Static variable in class org.apache.hadoop.security.WhitelistBasedResolver
- 
time in seconds by which the variable whitelist file is checked for updates 
- HADOOP_SECURITY_SASL_VARIABLEWHITELIST_ENABLE - Static variable in class org.apache.hadoop.security.WhitelistBasedResolver
- 
Enables/Disables variable whitelist 
- HADOOP_SECURITY_SASL_VARIABLEWHITELIST_FILE - Static variable in class org.apache.hadoop.security.WhitelistBasedResolver
- 
Path to the file to containing subnets and ip addresses to form variable whitelist. 
- HADOOP_SECURITY_SECURE_RANDOM_DEVICE_FILE_PATH_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_SECURE_RANDOM_DEVICE_FILE_PATH_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_SECURE_RANDOM_IMPL_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_SENSITIVE_CONFIG_KEYS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_SENSITIVE_CONFIG_KEYS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SECURITY_SERVICE_USER_NAME_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SHELL_MISSING_DEFAULT_FS_WARNING_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SHELL_MISSING_DEFAULT_FS_WARNING_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SHELL_SAFELY_DELETE_LIMIT_NUM_FILES - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SHELL_SAFELY_DELETE_LIMIT_NUM_FILES_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SOCKS_SERVER_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_SSL_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Deprecated. 
- HADOOP_SSL_ENABLED_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Deprecated. 
- HADOOP_TOKEN_FILE_LOCATION - Static variable in class org.apache.hadoop.security.UserGroupInformation
- 
Environment variable pointing to the token cache file 
- HADOOP_TOKEN_FILES - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HADOOP_UTIL_HASH_TYPE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Default value for HADOOP_UTIL_HASH_TYPE_KEY 
- HADOOP_UTIL_HASH_TYPE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
-  
- HadoopExecutors - Class in org.apache.hadoop.util.concurrent
- 
Factory methods for ExecutorService, ScheduledExecutorService instances. 
- HadoopIllegalArgumentException - Exception in org.apache.hadoop
- 
Indicates that a method has been passed illegal or invalid argument. 
- HadoopIllegalArgumentException(String) - Constructor for exception org.apache.hadoop.HadoopIllegalArgumentException
- 
Constructs exception with the specified detail message. 
- HadoopScheduledThreadPoolExecutor - Class in org.apache.hadoop.util.concurrent
- 
An extension of ScheduledThreadPoolExecutor that provides additional
 functionality. 
- HadoopScheduledThreadPoolExecutor(int) - Constructor for class org.apache.hadoop.util.concurrent.HadoopScheduledThreadPoolExecutor
-  
- HadoopScheduledThreadPoolExecutor(int, ThreadFactory) - Constructor for class org.apache.hadoop.util.concurrent.HadoopScheduledThreadPoolExecutor
-  
- HadoopScheduledThreadPoolExecutor(int, RejectedExecutionHandler) - Constructor for class org.apache.hadoop.util.concurrent.HadoopScheduledThreadPoolExecutor
-  
- HadoopScheduledThreadPoolExecutor(int, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.apache.hadoop.util.concurrent.HadoopScheduledThreadPoolExecutor
-  
- HadoopThreadPoolExecutor - Class in org.apache.hadoop.util.concurrent
- 
An extension of ThreadPoolExecutor that provides additional functionality. 
- HadoopThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>) - Constructor for class org.apache.hadoop.util.concurrent.HadoopThreadPoolExecutor
-  
- HadoopThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.hadoop.util.concurrent.HadoopThreadPoolExecutor
-  
- HadoopThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class org.apache.hadoop.util.concurrent.HadoopThreadPoolExecutor
-  
- HadoopThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.apache.hadoop.util.concurrent.HadoopThreadPoolExecutor
-  
- HadoopUncaughtExceptionHandler - Class in org.apache.hadoop.service.launcher
- 
- HadoopUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Constructor for class org.apache.hadoop.service.launcher.HadoopUncaughtExceptionHandler
- 
Create an instance delegating to the supplied handler if
 the exception is considered "simple". 
- HadoopUncaughtExceptionHandler() - Constructor for class org.apache.hadoop.service.launcher.HadoopUncaughtExceptionHandler
- 
Basic exception handler -logs simple exceptions, then continues. 
- halfDigest() - Method in class org.apache.hadoop.io.MD5Hash
- 
Construct a half-sized version of this MD5. 
- handle(DomainSocket) - Method in interface org.apache.hadoop.net.unix.DomainSocketWatcher.Handler
- 
Handles an event on a socket. 
- handle(Callback[]) - Method in class org.apache.hadoop.security.SaslRpcServer.SaslDigestCallbackHandler
-  
- handle(Callback[]) - Method in class org.apache.hadoop.security.SaslRpcServer.SaslGssCallbackHandler
-  
- handleEmptyDstDirectoryOnWindows(Path, File, Path, File) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
-  
- handleHttpInteraction(RestCsrfPreventionFilter.HttpInteraction) - Method in class org.apache.hadoop.security.http.RestCsrfPreventionFilter
- 
- handleKind(Text) - Method in class org.apache.hadoop.crypto.key.kms.KMSClientProvider.KMSTokenRenewer
-  
- handleKind(Text) - Method in class org.apache.hadoop.security.token.Token.TrivialRenewer
-  
- handleKind(Text) - Method in class org.apache.hadoop.security.token.TokenRenewer
- 
Does this renewer handle this kind of token? 
- handleRefresh(String, String[]) - Method in interface org.apache.hadoop.ipc.RefreshHandler
- 
Implement this method to accept refresh requests from the administrator. 
- HardLink - Class in org.apache.hadoop.fs
- 
Class for creating hardlinks. 
- HardLink() - Constructor for class org.apache.hadoop.fs.HardLink
-  
- HardLink.LinkStats - Class in org.apache.hadoop.fs
- 
HardLink statistics counters and methods. 
- HardLink.LinkStats() - Constructor for class org.apache.hadoop.fs.HardLink.LinkStats
-  
- HarFileSystem - Class in org.apache.hadoop.fs
- 
This is an implementation of the Hadoop Archive 
 Filesystem. 
- HarFileSystem() - Constructor for class org.apache.hadoop.fs.HarFileSystem
- 
public construction of harfilesystem 
- HarFileSystem(FileSystem) - Constructor for class org.apache.hadoop.fs.HarFileSystem
- 
Constructor to create a HarFileSystem with an
 underlying filesystem. 
- HarFs - Class in org.apache.hadoop.fs
-  
- hasCallerContext() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- hasCallerContext() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- hasCallerContext() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
 
- hasCallId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
required sint32 callId = 3;
 
- hasCallId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
required sint32 callId = 3;
 
- hasCallId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
required sint32 callId = 3;
 
- hasCallId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
required uint32 callId = 1;
 
- hasCallId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
required uint32 callId = 1;
 
- hasCallId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
required uint32 callId = 1;
 
- hasCapability(String) - Method in class org.apache.hadoop.fs.FSDataInputStream
-  
- hasCapability(String) - Method in class org.apache.hadoop.fs.FSDataOutputStream
-  
- hasCapability(String) - Method in interface org.apache.hadoop.fs.StreamCapabilities
- 
Query the stream for a specific capability. 
- hasChallenge() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional bytes challenge = 5;
 
- hasChallenge() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
optional bytes challenge = 5;
 
- hasChallenge() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
optional bytes challenge = 5;
 
- hasClassName() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto.Builder
- 
required string className = 1;
 
- hasClassName() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
- 
required string className = 1;
 
- hasClassName() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProtoOrBuilder
- 
required string className = 1;
 
- hasClassName() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
- 
required string className = 2;
 
- hasClassName() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
- 
required string className = 2;
 
- hasClassName() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfoOrBuilder
- 
required string className = 2;
 
- hasClientId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
required bytes clientId = 4;
 
- hasClientId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
required bytes clientId = 4;
 
- hasClientId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
required bytes clientId = 4;
 
- hasClientId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional bytes clientId = 7;
 
- hasClientId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional bytes clientId = 7;
 
- hasClientId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional bytes clientId = 7;
 
- hasClientProtocolVersion() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required uint64 clientProtocolVersion = 3;
 
- hasClientProtocolVersion() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
- 
required uint64 clientProtocolVersion = 3;
 
- hasClientProtocolVersion() - Method in interface org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProtoOrBuilder
- 
required uint64 clientProtocolVersion = 3;
 
- hasContext() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
- 
required string context = 1;
 
- hasContext() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
- 
required string context = 1;
 
- hasContext() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProtoOrBuilder
- 
required string context = 1;
 
- hasDeclaringClassProtocolName() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required string declaringClassProtocolName = 2;
 
- hasDeclaringClassProtocolName() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
- 
required string declaringClassProtocolName = 2;
 
- hasDeclaringClassProtocolName() - Method in interface org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProtoOrBuilder
- 
required string declaringClassProtocolName = 2;
 
- hasEffectiveUser() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
- 
optional string effectiveUser = 1;
 
- hasEffectiveUser() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
- 
optional string effectiveUser = 1;
 
- hasEffectiveUser() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProtoOrBuilder
- 
optional string effectiveUser = 1;
 
- hasErrorDetail() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional .hadoop.common.RpcResponseHeaderProto.RpcErrorCodeProto errorDetail = 6;
 
- hasErrorDetail() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional .hadoop.common.RpcResponseHeaderProto.RpcErrorCodeProto errorDetail = 6;
 
- hasErrorDetail() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional .hadoop.common.RpcResponseHeaderProto.RpcErrorCodeProto errorDetail = 6;
 
- hasErrorMsg() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional string errorMsg = 5;
 
- hasErrorMsg() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional string errorMsg = 5;
 
- hasErrorMsg() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional string errorMsg = 5;
 
- HAServiceProtocol - Interface in org.apache.hadoop.ha
- 
Protocol interface that provides High Availability related primitives to
 monitor and fail-over the service. 
- HAServiceProtocol.HAServiceState - Enum in org.apache.hadoop.ha
- 
An HA service may be in active or standby state. 
- HAServiceProtocol.RequestSource - Enum in org.apache.hadoop.ha
-  
- HAServiceProtocol.StateChangeRequestInfo - Class in org.apache.hadoop.ha
- 
Information describing the source for a request to change state. 
- HAServiceProtocol.StateChangeRequestInfo(HAServiceProtocol.RequestSource) - Constructor for class org.apache.hadoop.ha.HAServiceProtocol.StateChangeRequestInfo
-  
- HAServiceProtocolHelper - Class in org.apache.hadoop.ha
- 
- HAServiceProtocolHelper() - Constructor for class org.apache.hadoop.ha.HAServiceProtocolHelper
-  
- HAServiceProtocolPB - Interface in org.apache.hadoop.ha.protocolPB
-  
- HAServiceProtocolProtos - Class in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.GetServiceStatusRequestProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.GetServiceStatusRequestProto
 
- HAServiceProtocolProtos.GetServiceStatusRequestProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.GetServiceStatusRequestProto
 
- HAServiceProtocolProtos.GetServiceStatusRequestProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.GetServiceStatusResponseProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.GetServiceStatusResponseProto
 
- HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.GetServiceStatusResponseProto
 
- HAServiceProtocolProtos.GetServiceStatusResponseProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.HARequestSource - Enum in org.apache.hadoop.ha.proto
- 
Protobuf enum hadoop.common.HARequestSource
 
- HAServiceProtocolProtos.HAServiceProtocolService - Class in org.apache.hadoop.ha.proto
- 
Protobuf service hadoop.common.HAServiceProtocolService
 
- HAServiceProtocolProtos.HAServiceProtocolService() - Constructor for class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAServiceProtocolService
-  
- HAServiceProtocolProtos.HAServiceProtocolService.BlockingInterface - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.HAServiceProtocolService.Interface - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.HAServiceProtocolService.Stub - Class in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.HAServiceStateProto - Enum in org.apache.hadoop.ha.proto
- 
Protobuf enum hadoop.common.HAServiceStateProto
 
- HAServiceProtocolProtos.HAStateChangeRequestInfoProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.HAStateChangeRequestInfoProto
 
- HAServiceProtocolProtos.HAStateChangeRequestInfoProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.HAStateChangeRequestInfoProto
 
- HAServiceProtocolProtos.HAStateChangeRequestInfoProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.MonitorHealthRequestProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.MonitorHealthRequestProto
 
- HAServiceProtocolProtos.MonitorHealthRequestProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.MonitorHealthRequestProto
 
- HAServiceProtocolProtos.MonitorHealthRequestProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.MonitorHealthResponseProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.MonitorHealthResponseProto
 
- HAServiceProtocolProtos.MonitorHealthResponseProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.MonitorHealthResponseProto
 
- HAServiceProtocolProtos.MonitorHealthResponseProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.TransitionToActiveRequestProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToActiveRequestProto
 
- HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToActiveRequestProto
 
- HAServiceProtocolProtos.TransitionToActiveRequestProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.TransitionToActiveResponseProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToActiveResponseProto
 
- HAServiceProtocolProtos.TransitionToActiveResponseProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToActiveResponseProto
 
- HAServiceProtocolProtos.TransitionToActiveResponseProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.TransitionToObserverRequestProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToObserverRequestProto
 
- HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToObserverRequestProto
 
- HAServiceProtocolProtos.TransitionToObserverRequestProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.TransitionToObserverResponseProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToObserverResponseProto
 
- HAServiceProtocolProtos.TransitionToObserverResponseProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToObserverResponseProto
 
- HAServiceProtocolProtos.TransitionToObserverResponseProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.TransitionToStandbyRequestProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToStandbyRequestProto
 
- HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToStandbyRequestProto
 
- HAServiceProtocolProtos.TransitionToStandbyRequestProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceProtocolProtos.TransitionToStandbyResponseProto - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToStandbyResponseProto
 
- HAServiceProtocolProtos.TransitionToStandbyResponseProto.Builder - Class in org.apache.hadoop.ha.proto
- 
Protobuf type hadoop.common.TransitionToStandbyResponseProto
 
- HAServiceProtocolProtos.TransitionToStandbyResponseProtoOrBuilder - Interface in org.apache.hadoop.ha.proto
-  
- HAServiceTarget - Class in org.apache.hadoop.ha
- 
Represents a target of the client side HA administration commands. 
- HAServiceTarget() - Constructor for class org.apache.hadoop.ha.HAServiceTarget
-  
- hasExceptionClassName() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional string exceptionClassName = 4;
 
- hasExceptionClassName() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional string exceptionClassName = 4;
 
- hasExceptionClassName() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional string exceptionClassName = 4;
 
- hasExitStatus() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional int32 exitStatus = 1;
 
- hasExitStatus() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
- 
optional int32 exitStatus = 1;
 
- hasExitStatus() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProtoOrBuilder
- 
optional int32 exitStatus = 1;
 
- hasFlushed - Static variable in class org.apache.hadoop.metrics2.sink.RollingFileSystemSink
-  
- hash(Key) - Method in class org.apache.hadoop.util.bloom.HashFunction
- 
Hashes a specified key into several integers. 
- HASH_COUNT - Static variable in class org.apache.hadoop.io.BloomMapFile
-  
- hashBytes(byte[], int, int) - Static method in class org.apache.hadoop.io.WritableComparator
- 
Compute hash for binary data. 
- hashBytes(byte[], int) - Static method in class org.apache.hadoop.io.WritableComparator
- 
Compute hash for binary data. 
- hashCode() - Method in class org.apache.hadoop.fs.AbstractFileSystem
-  
- hashCode() - Method in class org.apache.hadoop.fs.ContentSummary
-  
- hashCode() - Method in class org.apache.hadoop.fs.DelegationTokenRenewer.RenewAction
-  
- hashCode() - Method in class org.apache.hadoop.fs.FileChecksum
-  
- hashCode() - Method in class org.apache.hadoop.fs.FileStatus
- 
Returns a hash code value for the object, which is defined as
 the hash code of the path name. 
- hashCode() - Method in class org.apache.hadoop.fs.LocatedFileStatus
- 
Returns a hash code value for the object, which is defined as
 the hash code of the path name. 
- hashCode() - Method in class org.apache.hadoop.fs.Path
-  
- hashCode() - Method in class org.apache.hadoop.fs.permission.AclEntry
-  
- hashCode() - Method in class org.apache.hadoop.fs.permission.AclStatus
-  
- hashCode() - Method in class org.apache.hadoop.fs.permission.FsPermission
-  
- hashCode() - Method in class org.apache.hadoop.fs.QuotaUsage
-  
- hashCode() - Method in class org.apache.hadoop.fs.shell.find.Result
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.MonitorHealthResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.GracefulFailoverResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.io.BinaryComparable
- 
Return a hash of the bytes returned from {#getBytes()}. 
- hashCode() - Method in class org.apache.hadoop.io.BooleanWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.BytesWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.ByteWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.DoubleWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.EnumSetWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.file.tfile.TFile.Reader.Scanner.Entry
-  
- hashCode() - Method in class org.apache.hadoop.io.file.tfile.Utils.Version
-  
- hashCode() - Method in class org.apache.hadoop.io.FloatWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.IntWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.LongWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.MapWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.MD5Hash
- 
Returns a hash code value for this object. 
- hashCode() - Method in class org.apache.hadoop.io.NullWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.retry.RetryPolicies.MultipleLinearRandomRetry
-  
- hashCode() - Method in class org.apache.hadoop.io.SequenceFile.Metadata
-  
- hashCode() - Method in class org.apache.hadoop.io.SequenceFile.Sorter.SegmentDescriptor
-  
- hashCode() - Method in class org.apache.hadoop.io.ShortWritable
- 
hash code 
- hashCode() - Method in class org.apache.hadoop.io.SortedMapWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.Text
-  
- hashCode() - Method in class org.apache.hadoop.io.VIntWritable
-  
- hashCode() - Method in class org.apache.hadoop.io.VLongWritable
-  
- hashCode() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseCollectionProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.proto.RefreshCallQueueProtocolProtos.RefreshCallQueueResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
-  
- hashCode() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
-  
- hashCode() - Method in class org.apache.hadoop.ipc.RetryCache.CacheEntry
-  
- hashCode() - Method in class org.apache.hadoop.ipc.RetryCache.CacheEntryWithPayload
- 
Override hashcode to avoid findbugs warnings 
- hashCode() - Method in class org.apache.hadoop.metrics2.AbstractMetric
-  
- hashCode() - Method in class org.apache.hadoop.metrics2.MetricsTag
-  
- hashCode() - Method in class org.apache.hadoop.net.InnerNodeImpl
-  
- hashCode() - Method in class org.apache.hadoop.net.SocksSocketFactory
-  
- hashCode() - Method in class org.apache.hadoop.net.StandardSocketFactory
-  
- hashCode() - Method in class org.apache.hadoop.record.Buffer
- 
Deprecated. 
- hashCode() - Method in class org.apache.hadoop.record.meta.FieldTypeInfo
- 
Deprecated. We use a basic hashcode implementation, since this class will likely not
 be used as a hashmap key 
- hashCode() - Method in class org.apache.hadoop.record.meta.MapTypeID
- 
Deprecated. We use a basic hashcode implementation, since this class will likely not
 be used as a hashmap key 
- hashCode() - Method in class org.apache.hadoop.record.meta.StructTypeID
- 
Deprecated. 
- hashCode() - Method in class org.apache.hadoop.record.meta.TypeID
- 
Deprecated. We use a basic hashcode implementation, since this class will likely not
 be used as a hashmap key 
- hashCode() - Method in class org.apache.hadoop.record.meta.VectorTypeID
- 
Deprecated. We use a basic hashcode implementation, since this class will likely not
 be used as a hashmap key 
- hashCode() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.RefreshAuthorizationPolicyProtocolProtos.RefreshServiceAclResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshSuperUserGroupsConfigurationResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.RefreshUserMappingsProtocolProtos.RefreshUserToGroupsMappingsResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
-  
- hashCode() - Method in class org.apache.hadoop.security.token.delegation.AbstractDelegationTokenIdentifier
-  
- hashCode() - Method in class org.apache.hadoop.security.token.Token
-  
- hashCode() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
Return the hash of the subject. 
- hashCode() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
-  
- hashCode() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ListSpanReceiversResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto
-  
- hashCode() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverResponseProto
-  
- hashCode() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
-  
- hashCode() - Method in class org.apache.hadoop.util.ComparableVersion
-  
- HashFunction - Class in org.apache.hadoop.util.bloom
- 
Implements a hash object that returns a certain number of hashed values. 
- HashFunction(int, int, int) - Constructor for class org.apache.hadoop.util.bloom.HashFunction
- 
Constructor. 
- hasId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto.Builder
- 
required int64 id = 1;
 
- hasId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProto
- 
required int64 id = 1;
 
- hasId() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.AddSpanReceiverResponseProtoOrBuilder
- 
required int64 id = 1;
 
- hasId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto.Builder
- 
required int64 id = 1;
 
- hasId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProto
- 
required int64 id = 1;
 
- hasId() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.RemoveSpanReceiverRequestProtoOrBuilder
- 
required int64 id = 1;
 
- hasId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo.Builder
- 
required int64 id = 1;
 
- hasId() - Method in class org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfo
- 
required int64 id = 1;
 
- hasId() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.SpanReceiverListInfoOrBuilder
- 
required int64 id = 1;
 
- hasIdentifier() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto.Builder
- 
optional string identifier = 1;
 
- hasIdentifier() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProto
- 
optional string identifier = 1;
 
- hasIdentifier() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshRequestProtoOrBuilder
- 
optional string identifier = 1;
 
- hasIdentifier() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required bytes identifier = 1;
 
- hasIdentifier() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
- 
required bytes identifier = 1;
 
- hasIdentifier() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.TokenProtoOrBuilder
- 
required bytes identifier = 1;
 
- hasKerberosCredentials() - Method in class org.apache.hadoop.security.UserGroupInformation
- 
checks if logged in using kerberos 
- hasKey() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
- 
required string key = 1;
 
- hasKey() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
- 
required string key = 1;
 
- hasKey() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ConfigPairOrBuilder
- 
required string key = 1;
 
- hasKind() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required string kind = 3;
 
- hasKind() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
- 
required string kind = 3;
 
- hasKind() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.TokenProtoOrBuilder
- 
required string kind = 3;
 
- hasMechanism() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
required string mechanism = 2;
 
- hasMechanism() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
required string mechanism = 2;
 
- hasMechanism() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
required string mechanism = 2;
 
- hasMethod() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
required string method = 1;
 
- hasMethod() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
required string method = 1;
 
- hasMethod() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
required string method = 1;
 
- hasMethodName() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto.Builder
- 
required string methodName = 1;
 
- hasMethodName() - Method in class org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProto
- 
required string methodName = 1;
 
- hasMethodName() - Method in interface org.apache.hadoop.ipc.protobuf.ProtobufRpcEngineProtos.RequestHeaderProtoOrBuilder
- 
required string methodName = 1;
 
- hasMillisToCede() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto.Builder
- 
required uint32 millisToCede = 1;
 
- hasMillisToCede() - Method in class org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProto
- 
required uint32 millisToCede = 1;
 
- hasMillisToCede() - Method in interface org.apache.hadoop.ha.proto.ZKFCProtocolProtos.CedeActiveRequestProtoOrBuilder
- 
required uint32 millisToCede = 1;
 
- hasMore() - Method in interface org.apache.hadoop.fs.BatchedRemoteIterator.BatchedEntries
-  
- hasMore() - Method in class org.apache.hadoop.fs.BatchedRemoteIterator.BatchedListEntries
-  
- hasNewExpiryTime() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto.Builder
- 
required uint64 newExpiryTime = 1;
 
- hasNewExpiryTime() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProto
- 
required uint64 newExpiryTime = 1;
 
- hasNewExpiryTime() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenResponseProtoOrBuilder
- 
required uint64 newExpiryTime = 1;
 
- hasNext() - Method in class org.apache.hadoop.fs.BatchedRemoteIterator
-  
- hasNext() - Method in interface org.apache.hadoop.fs.RemoteIterator
- 
Returns true if the iteration has more elements. 
- hasNext() - Method in class org.apache.hadoop.util.IntrusiveCollection.IntrusiveIterator
-  
- hasNext() - Method in class org.apache.hadoop.util.LightWeightGSet.SetIterator
-  
- hasNotReadyReason() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
- 
optional string notReadyReason = 3;
 
- hasNotReadyReason() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
- 
optional string notReadyReason = 3;
 
- hasNotReadyReason() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProtoOrBuilder
- 
optional string notReadyReason = 3;
 
- hasParentId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
- 
optional int64 parentId = 2;
 
- hasParentId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
- 
optional int64 parentId = 2;
 
- hasParentId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProtoOrBuilder
- 
optional int64 parentId = 2;
 
- hasPassword() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required bytes password = 2;
 
- hasPassword() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
- 
required bytes password = 2;
 
- hasPassword() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.TokenProtoOrBuilder
- 
required bytes password = 2;
 
- hasPattern() - Method in class org.apache.hadoop.fs.GlobFilter
-  
- hasProtocol() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
- 
optional string protocol = 3;
 
- hasProtocol() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
- 
optional string protocol = 3;
 
- hasProtocol() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProtoOrBuilder
- 
optional string protocol = 3;
 
- hasProtocol() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
- 
required string protocol = 1;
 
- hasProtocol() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
- 
required string protocol = 1;
 
- hasProtocol() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProtoOrBuilder
- 
required string protocol = 1;
 
- hasProtocol() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto.Builder
- 
required string protocol = 1;
 
- hasProtocol() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProto
- 
required string protocol = 1;
 
- hasProtocol() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolVersionsRequestProtoOrBuilder
- 
required string protocol = 1;
 
- hasProtocol() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional string protocol = 3;
 
- hasProtocol() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
optional string protocol = 3;
 
- hasProtocol() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
optional string protocol = 3;
 
- hasReadyToBecomeActive() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
- 
optional bool readyToBecomeActive = 2;
 
- hasReadyToBecomeActive() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
- 
optional bool readyToBecomeActive = 2;
 
- hasReadyToBecomeActive() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProtoOrBuilder
- 
optional bool readyToBecomeActive = 2;
 
- hasRealUser() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto.Builder
- 
optional string realUser = 2;
 
- hasRealUser() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProto
- 
optional string realUser = 2;
 
- hasRealUser() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.UserInformationProtoOrBuilder
- 
optional string realUser = 2;
 
- hasRenewer() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto.Builder
- 
required string renewer = 1;
 
- hasRenewer() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProto
- 
required string renewer = 1;
 
- hasRenewer() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenRequestProtoOrBuilder
- 
required string renewer = 1;
 
- hasReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- hasReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProto
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- hasReqInfo() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToActiveRequestProtoOrBuilder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- hasReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- hasReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProto
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- hasReqInfo() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToObserverRequestProtoOrBuilder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- hasReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto.Builder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- hasReqInfo() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProto
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- hasReqInfo() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.TransitionToStandbyRequestProtoOrBuilder
- 
required .hadoop.common.HAStateChangeRequestInfoProto reqInfo = 1;
 
- hasReqSource() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto.Builder
- 
required .hadoop.common.HARequestSource reqSource = 1;
 
- hasReqSource() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProto
- 
required .hadoop.common.HARequestSource reqSource = 1;
 
- hasReqSource() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.HAStateChangeRequestInfoProtoOrBuilder
- 
required .hadoop.common.HARequestSource reqSource = 1;
 
- hasRetryCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional sint32 retryCount = 5 [default = -1];
 
- hasRetryCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional sint32 retryCount = 5 [default = -1];
 
- hasRetryCount() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional sint32 retryCount = 5 [default = -1];
 
- hasRetryCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional sint32 retryCount = 8 [default = -1];
 
- hasRetryCount() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional sint32 retryCount = 8 [default = -1];
 
- hasRetryCount() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional sint32 retryCount = 8 [default = -1];
 
- hasRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto.Builder
- 
required string rpcKind = 2;
 
- hasRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProto
- 
required string rpcKind = 2;
 
- hasRpcKind() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.GetProtocolSignatureRequestProtoOrBuilder
- 
required string rpcKind = 2;
 
- hasRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto.Builder
- 
required string rpcKind = 1;
 
- hasRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProto
- 
required string rpcKind = 1;
 
- hasRpcKind() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolVersionProtoOrBuilder
- 
required string rpcKind = 1;
 
- hasRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RpcKindProto rpcKind = 1;
 
- hasRpcKind() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional .hadoop.common.RpcKindProto rpcKind = 1;
 
- hasRpcKind() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional .hadoop.common.RpcKindProto rpcKind = 1;
 
- hasRpcOp() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2;
 
- hasRpcOp() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2;
 
- hasRpcOp() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2;
 
- hasSenderName() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional string senderName = 3;
 
- hasSenderName() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
- 
optional string senderName = 3;
 
- hasSenderName() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProtoOrBuilder
- 
optional string senderName = 3;
 
- hasServerId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth.Builder
- 
optional string serverId = 4;
 
- hasServerId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuth
- 
optional string serverId = 4;
 
- hasServerId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.SaslAuthOrBuilder
- 
optional string serverId = 4;
 
- hasServerIpcVersionNum() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional uint32 serverIpcVersionNum = 3;
 
- hasServerIpcVersionNum() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional uint32 serverIpcVersionNum = 3;
 
- hasServerIpcVersionNum() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional uint32 serverIpcVersionNum = 3;
 
- hasService() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto.Builder
- 
required string service = 4;
 
- hasService() - Method in class org.apache.hadoop.security.proto.SecurityProtos.TokenProto
- 
required string service = 4;
 
- hasService() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.TokenProtoOrBuilder
- 
required string service = 4;
 
- hasShutdownHook(Runnable) - Method in class org.apache.hadoop.util.ShutdownHookManager
- 
Indicates if a shutdownHook is registered or not. 
- hasSignature() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto.Builder
- 
optional bytes signature = 2;
 
- hasSignature() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProto
- 
optional bytes signature = 2;
 
- hasSignature() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCCallerContextProtoOrBuilder
- 
optional bytes signature = 2;
 
- hasState() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto.Builder
- 
required .hadoop.common.HAServiceStateProto state = 1;
 
- hasState() - Method in class org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProto
- 
required .hadoop.common.HAServiceStateProto state = 1;
 
- hasState() - Method in interface org.apache.hadoop.ha.proto.HAServiceProtocolProtos.GetServiceStatusResponseProtoOrBuilder
- 
required .hadoop.common.HAServiceStateProto state = 1;
 
- hasState() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
required .hadoop.common.RpcSaslProto.SaslState state = 2;
 
- hasState() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
required .hadoop.common.RpcSaslProto.SaslState state = 2;
 
- hasState() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
required .hadoop.common.RpcSaslProto.SaslState state = 2;
 
- hasStateId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional int64 stateId = 8;
 
- hasStateId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional int64 stateId = 8;
 
- hasStateId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional int64 stateId = 8;
 
- hasStateId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
optional int64 stateId = 9;
 
- hasStateId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
optional int64 stateId = 9;
 
- hasStateId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
optional int64 stateId = 9;
 
- hasStatus() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto.Builder
- 
required .hadoop.common.RpcResponseHeaderProto.RpcStatusProto status = 2;
 
- hasStatus() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProto
- 
required .hadoop.common.RpcResponseHeaderProto.RpcStatusProto status = 2;
 
- hasStatus() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcResponseHeaderProtoOrBuilder
- 
required .hadoop.common.RpcResponseHeaderProto.RpcStatusProto status = 2;
 
- hasTask() - Method in class org.apache.hadoop.conf.ReconfigurationTaskStatus
- 
Return true if
   - A reconfiguration task has finished or
   - an active reconfiguration task is running 
- hasToken() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
optional bytes token = 3;
 
- hasToken() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
optional bytes token = 3;
 
- hasToken() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
optional bytes token = 3;
 
- hasToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto.Builder
- 
required .hadoop.common.TokenProto token = 1;
 
- hasToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProto
- 
required .hadoop.common.TokenProto token = 1;
 
- hasToken() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.CancelDelegationTokenRequestProtoOrBuilder
- 
required .hadoop.common.TokenProto token = 1;
 
- hasToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto.Builder
- 
optional .hadoop.common.TokenProto token = 1;
 
- hasToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProto
- 
optional .hadoop.common.TokenProto token = 1;
 
- hasToken() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.GetDelegationTokenResponseProtoOrBuilder
- 
optional .hadoop.common.TokenProto token = 1;
 
- hasToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto.Builder
- 
required .hadoop.common.TokenProto token = 1;
 
- hasToken() - Method in class org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProto
- 
required .hadoop.common.TokenProto token = 1;
 
- hasToken() - Method in interface org.apache.hadoop.security.proto.SecurityProtos.RenewDelegationTokenRequestProtoOrBuilder
- 
required .hadoop.common.TokenProto token = 1;
 
- hasTraceId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto.Builder
- 
optional int64 traceId = 1;
 
- hasTraceId() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProto
- 
optional int64 traceId = 1;
 
- hasTraceId() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RPCTraceInfoProtoOrBuilder
- 
optional int64 traceId = 1;
 
- hasTraceInfo() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto.Builder
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- hasTraceInfo() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProto
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- hasTraceInfo() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
- 
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
 
- hasUser() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto.Builder
- 
required string user = 1;
 
- hasUser() - Method in class org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProto
- 
required string user = 1;
 
- hasUser() - Method in interface org.apache.hadoop.tools.proto.GetUserMappingsProtocolProtos.GetGroupsForUserRequestProtoOrBuilder
- 
required string user = 1;
 
- hasUserInfo() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto.Builder
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- hasUserInfo() - Method in class org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProto
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- hasUserInfo() - Method in interface org.apache.hadoop.ipc.protobuf.IpcConnectionContextProtos.IpcConnectionContextProtoOrBuilder
- 
optional .hadoop.common.UserInformationProto userInfo = 2;
 
- hasUserMessage() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto.Builder
- 
optional string userMessage = 2;
 
- hasUserMessage() - Method in class org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProto
- 
optional string userMessage = 2;
 
- hasUserMessage() - Method in interface org.apache.hadoop.ipc.proto.GenericRefreshProtocolProtos.GenericRefreshResponseProtoOrBuilder
- 
optional string userMessage = 2;
 
- hasVal() - Method in class org.apache.hadoop.util.Waitable
-  
- hasValue() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair.Builder
- 
required string value = 2;
 
- hasValue() - Method in class org.apache.hadoop.tracing.TraceAdminPB.ConfigPair
- 
required string value = 2;
 
- hasValue() - Method in interface org.apache.hadoop.tracing.TraceAdminPB.ConfigPairOrBuilder
- 
required string value = 2;
 
- hasVersion() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto.Builder
- 
required uint64 version = 1;
 
- hasVersion() - Method in class org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProto
- 
required uint64 version = 1;
 
- hasVersion() - Method in interface org.apache.hadoop.ipc.protobuf.ProtocolInfoProtos.ProtocolSignatureProtoOrBuilder
- 
required uint64 version = 1;
 
- hasVersion() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto.Builder
- 
optional uint32 version = 1;
 
- hasVersion() - Method in class org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProto
- 
optional uint32 version = 1;
 
- hasVersion() - Method in interface org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcSaslProtoOrBuilder
- 
optional uint32 version = 1;
 
- hasWarnedDeprecation(String) - Static method in class org.apache.hadoop.conf.Configuration
- 
Returns whether or not a deprecated name has been warned. 
- hasWinutilsPath() - Static method in class org.apache.hadoop.util.Shell
- 
Predicate to indicate whether or not the path to winutils is known. 
- hbMakeCodeLengths(char[], int[], int, int) - Static method in class org.apache.hadoop.io.compress.bzip2.CBZip2OutputStream
- 
This method is accessible by subclasses for historical purposes. 
- HEADER_DEFAULT - Static variable in class org.apache.hadoop.security.http.RestCsrfPreventionFilter
-  
- HEADER_USER_AGENT - Static variable in class org.apache.hadoop.security.http.RestCsrfPreventionFilter
-  
- headMap(WritableComparable) - Method in class org.apache.hadoop.io.SortedMapWritable
-  
- HealthCheckFailedException - Exception in org.apache.hadoop.ha
- 
Exception thrown to indicate that health check of a service failed. 
- HealthCheckFailedException(String) - Constructor for exception org.apache.hadoop.ha.HealthCheckFailedException
-  
- HealthCheckFailedException(String, Throwable) - Constructor for exception org.apache.hadoop.ha.HealthCheckFailedException
-  
- help - Variable in class org.apache.hadoop.ha.HAAdmin.UsageInfo
-  
- hexchars - Static variable in class org.apache.hadoop.record.Utils
- 
Deprecated. 
- hflush() - Method in class org.apache.hadoop.fs.FSDataOutputStream
-  
- HFLUSH - Static variable in interface org.apache.hadoop.fs.StreamCapabilities
- 
- hflush() - Method in interface org.apache.hadoop.fs.Syncable
- 
Flush out the data in client's user buffer. 
- hflush() - Method in class org.apache.hadoop.io.SequenceFile.Writer
-  
- hideHeaders() - Method in class org.apache.hadoop.tools.TableListing.Builder
- 
Whether to hide column headers in table output 
- hostName(String) - Method in class org.apache.hadoop.http.HttpServer2.Builder
- 
Set the hostname of the http server. 
- HOSTNAME_PATTERN - Static variable in class org.apache.hadoop.security.SecurityUtil
-  
- HostsFileReader.HostDetails - Class in org.apache.hadoop.util
- 
An atomic view of the included and excluded hosts 
- hsync() - Method in class org.apache.hadoop.fs.FSDataOutputStream
-  
- HSYNC - Static variable in interface org.apache.hadoop.fs.StreamCapabilities
- 
- hsync() - Method in interface org.apache.hadoop.fs.Syncable
- 
Similar to posix fsync, flush out the data in client's user buffer 
 all the way to the disk device (but the disk may have it in its cache). 
- hsync() - Method in class org.apache.hadoop.io.SequenceFile.Writer
-  
- HtmlQuoting - Class in org.apache.hadoop.http
- 
This class is responsible for quoting HTML characters. 
- HtmlQuoting() - Constructor for class org.apache.hadoop.http.HtmlQuoting
-  
- HTTP_POLICY_HTTP_ONLY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Deprecated. 
- HTTP_POLICY_HTTPS_ONLY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
- 
Deprecated. 
- HttpConfig.Policy - Enum in org.apache.hadoop.http
-  
- HttpCrossOriginFilterInitializer - Class in org.apache.hadoop.security
-  
- HttpCrossOriginFilterInitializer() - Constructor for class org.apache.hadoop.security.HttpCrossOriginFilterInitializer
-  
- HttpFileSystem - Class in org.apache.hadoop.fs.http
- 
A Filesystem that reads from HTTP endpoint. 
- HttpFileSystem() - Constructor for class org.apache.hadoop.fs.http.HttpFileSystem
-  
- HttpRequestLog - Class in org.apache.hadoop.http
- 
RequestLog object for use with Http 
- HttpRequestLog() - Constructor for class org.apache.hadoop.http.HttpRequestLog
-  
- HttpRequestLogAppender - Class in org.apache.hadoop.http
- 
Log4j Appender adapter for HttpRequestLog 
- HttpRequestLogAppender() - Constructor for class org.apache.hadoop.http.HttpRequestLogAppender
-  
- HttpServer.QuotingInputFilter - Class in org.apache.hadoop.http
- 
Deprecated. A Servlet input filter that quotes all HTML active characters in the
 parameter names and values. 
- HttpServer.QuotingInputFilter() - Constructor for class org.apache.hadoop.http.HttpServer.QuotingInputFilter
- 
Deprecated. 
- HttpServer.QuotingInputFilter.RequestQuoter - Class in org.apache.hadoop.http
- 
Deprecated. 
- HttpServer.QuotingInputFilter.RequestQuoter(HttpServletRequest) - Constructor for class org.apache.hadoop.http.HttpServer.QuotingInputFilter.RequestQuoter
- 
Deprecated. 
- HttpServer.StackServlet - Class in org.apache.hadoop.http
- 
Deprecated. A very simple servlet to serve up a text representation of the current
 stack traces. 
- HttpServer.StackServlet() - Constructor for class org.apache.hadoop.http.HttpServer.StackServlet
- 
Deprecated. 
- HttpServer2.Builder - Class in org.apache.hadoop.http
- 
Class to construct instances of HTTP server with specific options. 
- HttpServer2.Builder() - Constructor for class org.apache.hadoop.http.HttpServer2.Builder
-  
- HttpServer2.QuotingInputFilter - Class in org.apache.hadoop.http
- 
A Servlet input filter that quotes all HTML active characters in the
 parameter names and values. 
- HttpServer2.QuotingInputFilter() - Constructor for class org.apache.hadoop.http.HttpServer2.QuotingInputFilter
-  
- HttpServer2.QuotingInputFilter.RequestQuoter - Class in org.apache.hadoop.http
-  
- HttpServer2.QuotingInputFilter.RequestQuoter(HttpServletRequest) - Constructor for class org.apache.hadoop.http.HttpServer2.QuotingInputFilter.RequestQuoter
-  
- HttpServer2.StackServlet - Class in org.apache.hadoop.http
- 
A very simple servlet to serve up a text representation of the current
 stack traces. 
- HttpServer2.StackServlet() - Constructor for class org.apache.hadoop.http.HttpServer2.StackServlet
-  
- HttpServer2.XFrameOption - Enum in org.apache.hadoop.http
- 
The X-FRAME-OPTIONS header in HTTP response to mitigate clickjacking
 attack. 
- HttpsFileSystem - Class in org.apache.hadoop.fs.http
- 
A Filesystem that reads from HTTPS endpoint. 
- HttpsFileSystem() - Constructor for class org.apache.hadoop.fs.http.HttpsFileSystem
-