Skip navigation links
elasticsearch-hadoop
A B C D E F G H I J K L M N O P R S T U V W 

A

abortJob(JobState) - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
Abort this job execution.
AbortOnFailure<I extends Exceptional,O,C extends ErrorCollector<O>> - Class in org.elasticsearch.hadoop.handler.impl
 
AbortOnFailure() - Constructor for class org.elasticsearch.hadoop.handler.impl.AbortOnFailure
 
abortTask(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOldAPIOutputCommitter
 
abortTask(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOutputCommitter
 
abortTask(TaskState) - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
Abort this task execution
AbstractEsRDD<T> - Class in org.elasticsearch.spark.rdd
 
AbstractEsRDD(SparkContext, Map<String, String>, ClassTag<T>) - Constructor for class org.elasticsearch.spark.rdd.AbstractEsRDD
 
AbstractEsRDD$ - Class in org.elasticsearch.spark.rdd
 
AbstractEsRDD$() - Constructor for class org.elasticsearch.spark.rdd.AbstractEsRDD$
 
AbstractEsRDDIterator<T> - Class in org.elasticsearch.spark.rdd
 
AbstractEsRDDIterator(TaskContext, PartitionDefinition) - Constructor for class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
AbstractHandlerLoader<E extends ErrorHandler> - Class in org.elasticsearch.hadoop.handler.impl
Performs the construction and initialization of ErrorHandler instances, implementations of which may be provided by third parties.
AbstractHandlerLoader(Class<E>) - Constructor for class org.elasticsearch.hadoop.handler.impl.AbstractHandlerLoader
 
AbstractHandlerLoader.NamedHandlers - Enum in org.elasticsearch.hadoop.handler.impl
 
AbstractPigEsInputRecordReader() - Constructor for class org.elasticsearch.hadoop.pig.EsPigInputFormat.AbstractPigEsInputRecordReader
 
AbstractPigEsInputRecordReader(InputSplit, Configuration, Reporter) - Constructor for class org.elasticsearch.hadoop.pig.EsPigInputFormat.AbstractPigEsInputRecordReader
 
AbstractWritableEsInputRecordReader() - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat.AbstractWritableEsInputRecordReader
 
AbstractWritableEsInputRecordReader(InputSplit, Configuration, Reporter) - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat.AbstractWritableEsInputRecordReader
 
ack(Object) - Method in class org.elasticsearch.storm.EsSpout
 
activate() - Method in class org.elasticsearch.storm.EsSpout
 
add(long, T) - Method in class org.elasticsearch.spark.sql.streaming.NullMetadataLog
 
addBatch(long, Dataset<Row>) - Method in class org.elasticsearch.spark.sql.streaming.EsSparkSqlStreamingSink
 
addEsToken(EsToken) - Method in class org.elasticsearch.hadoop.mr.security.HadoopUser
 
addEsToken(EsToken) - Method in class org.elasticsearch.hadoop.security.JdkUser
 
addEsToken(EsToken) - Method in interface org.elasticsearch.hadoop.security.User
Adds the given esToken to the user
addOutputFormat(Configuration, Class<? extends OutputFormat>...) - Static method in class org.elasticsearch.hadoop.mr.MultiOutputFormat
 
addToArray(Object, List<Object>) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
addToArray(Object, List<Object>) - Method in class org.elasticsearch.hadoop.pig.PigValueReader
 
addToArray(Object, List<Object>) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
addToArray(Object, List<Object>) - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
addToBuffer(ScalaEsRow, Object, Object) - Method in interface org.elasticsearch.spark.sql.RowValueReader
 
addTokenForJob(RestClient, ClusterName, User, Job) - Static method in class org.elasticsearch.hadoop.mr.security.TokenUtil
Retrieves an authentication token from the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.
addTokenForJobConf(RestClient, ClusterName, User, JobConf) - Static method in class org.elasticsearch.hadoop.mr.security.TokenUtil
Retrieves an authentication token from the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job configuration.
addToMap(Object, Object, Object) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
addToMap(Object, Object, Object) - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
ALL - Static variable in enum org.elasticsearch.hadoop.mr.Counter
 
apply(T1, T2, T3) - Static method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
apply(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
apply(T1, T2, T3, T4) - Static method in class org.elasticsearch.spark.sql.streaming.EsSinkStatus
 
apply(T1, T2) - Static method in class org.elasticsearch.spark.sql.streaming.JobState
 
apply(T1) - Static method in class org.elasticsearch.spark.sql.streaming.TaskCommit
 
apply(T1, T2) - Static method in class org.elasticsearch.spark.sql.streaming.TaskState
 
arrayDepth(Object) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
arrayDepth(Object) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
arrayExclude() - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
arrayFields() - Method in interface org.elasticsearch.spark.sql.RowValueReader
 
arrayInclude() - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
asJobConf(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
asProperties() - Method in class org.elasticsearch.hadoop.cfg.CompositeSettings
 
asProperties() - Method in class org.elasticsearch.hadoop.cfg.FilteredSettings
 
asProperties() - Method in class org.elasticsearch.hadoop.cfg.HadoopSettings
 
asProperties() - Method in class org.elasticsearch.hadoop.cfg.PropertiesSettings
 
asProperties() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
asProperties(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
asProperties() - Method in class org.elasticsearch.spark.cfg.SparkSettings
 
asProperties() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
AuthenticationMethod - Enum in org.elasticsearch.hadoop.security
Defines the constants for determining the type of authentication to Elasticsearch we will be using.
AutoElasticsearch - Class in org.elasticsearch.storm.security
A storm plugin that logs in with Kerberos, acquires an Elasticsearch API Token, serializes it for transit, unpacks it on the storm worker side, and manages the process of updating or acquiring new tokens when the token is expired.
AutoElasticsearch() - Constructor for class org.elasticsearch.storm.security.AutoElasticsearch
 
availableShortType() - Static method in class org.elasticsearch.hadoop.mr.WritableCompatUtil
 
availableShortWritable(short) - Static method in class org.elasticsearch.hadoop.mr.WritableCompatUtil
 

B

BaseEventConverter<E extends Exceptional> - Class in org.elasticsearch.hadoop.handler.impl.elasticsearch
Base implementation for converting failure events into ECS documents
BaseEventConverter(String, String) - Constructor for class org.elasticsearch.hadoop.handler.impl.elasticsearch.BaseEventConverter
 
BaseExceptional - Class in org.elasticsearch.hadoop.handler.impl
Provides a basic implementation of an exceptional event to be passed between error handlers.
BaseExceptional(Exception, List<String>) - Constructor for class org.elasticsearch.hadoop.handler.impl.BaseExceptional
 
batchId() - Method in class org.elasticsearch.spark.sql.streaming.JobState
 
beginDoc() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
beginGeoField() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
beginLeadMetadata() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
beginSource() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
beginTrailMetadata() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
binaryValue(byte[]) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
binaryValue(byte[]) - Method in class org.elasticsearch.hadoop.pig.PigValueReader
 
binaryValue(byte[]) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
booleanValue(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
build() - Method in class org.elasticsearch.hadoop.security.KeystoreWrapper.KeystoreBuilder
 
buildScan() - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
buildScan(String[]) - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
buildScan(String[], Filter[]) - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
bytesConverter() - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
bytesConverter() - Method in class org.elasticsearch.spark.sql.EsDataFrameWriter
 
bytesConverter() - Method in class org.elasticsearch.spark.sql.streaming.EsStreamQueryWriter
 
byteType() - Method in class org.elasticsearch.hadoop.hive.HiveValueReader
 
byteType() - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
byteValue(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 

C

cancel(Token<?>, Configuration) - Method in class org.elasticsearch.hadoop.mr.security.EsTokenIdentifier.Renewer
 
caseClassCache() - Method in class org.elasticsearch.spark.serialization.ReflectionUtils$
 
caseClassCache() - Static method in class org.elasticsearch.spark.serialization.ReflectionUtils
 
caseClassValues(Product) - Method in class org.elasticsearch.spark.serialization.ReflectionUtils$
 
caseClassValues(Product) - Static method in class org.elasticsearch.spark.serialization.ReflectionUtils
 
cfg - Variable in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsRecordWriter
 
cfg() - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
CFG_FIELD - Static variable in class org.elasticsearch.hadoop.mr.MultiOutputFormat
 
checkCompatibility(SparkSession) - Method in class org.elasticsearch.spark.sql.streaming.StructuredStreamingVersionLock$
Checks the spark session to make sure that it contains a compatible version.
checkCompatibility(SparkSession) - Static method in class org.elasticsearch.spark.sql.streaming.StructuredStreamingVersionLock
Checks the spark session to make sure that it contains a compatible version.
checkNull(Function2<String, Parser, Object>, String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
checkOutputSpecs(JobContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.elasticsearch.hadoop.mr.MultiOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.elasticsearch.hadoop.mr.MultiOutputFormat
 
checkpoint() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDD
 
checkSchema(ResourceSchema) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
cleanup() - Method in class org.elasticsearch.storm.EsBolt
 
cleanupJob(JobContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOldAPIOutputCommitter
Deprecated.
cleanupJob(JobContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOutputCommitter
Deprecated.
cleanupOnFailure(String, Job) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
cleanupOnSuccess(String, Job) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
clear() - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
close() - Method in interface org.elasticsearch.hadoop.handler.ErrorHandler
Called at the close of the connector to clean up any internal resources.
close() - Method in class org.elasticsearch.hadoop.handler.impl.AbortOnFailure
 
close() - Method in class org.elasticsearch.hadoop.handler.impl.DropAndLog
 
close() - Method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
close() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
close(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsRecordWriter
 
close(Reporter) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsRecordWriter
 
close() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
close() - Method in class org.elasticsearch.storm.EsSpout
 
closeIfNeeded() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
commitJob(JobState, Seq<TaskCommit>) - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
Commit the results of each of the tasks to the execution log.
commitLog() - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
 
commitTask(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOldAPIOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOutputCommitter
 
commitTask(TaskState) - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
Commit this task's transaction.
compactLogs(Seq<EsSinkStatus>) - Method in class org.elasticsearch.spark.sql.streaming.EsSinkMetadataLog
 
Comparator() - Constructor for class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable.Comparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable.Comparator
Compare the buffers in serialized form.
CompatibilityLevel - Interface in org.elasticsearch.spark.rdd
 
CompositeSettings - Class in org.elasticsearch.hadoop.cfg
Provides a composite view of configurations, using a hierarchical model for property lookup as well as immutable treatment of the underlying configurations.
CompositeSettings(Collection<Settings>) - Constructor for class org.elasticsearch.hadoop.cfg.CompositeSettings
 
compute(Partition, TaskContext) - Method in class org.elasticsearch.spark.rdd.JavaEsRDD
 
compute(Partition, TaskContext) - Method in class org.elasticsearch.spark.rdd.ScalaEsRDD
 
compute(Partition, TaskContext) - Method in class org.elasticsearch.spark.sql.ScalaEsRowRDD
 
CONF_CLIENT_CONF - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_CLIENT_INHERIT - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_CLIENT_NODES - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_CLIENT_PORT - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_CLIENT_RESOURCE - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_LABEL - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_LOGGER_CLASS - Static variable in class org.elasticsearch.hadoop.handler.impl.DropAndLog
 
CONF_LOGGER_LEVEL - Static variable in class org.elasticsearch.hadoop.handler.impl.DropAndLog
 
CONF_LOGGER_NAME - Static variable in class org.elasticsearch.hadoop.handler.impl.DropAndLog
 
CONF_PASS_REASON_SUFFIX - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_RETURN_ERROR - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_RETURN_ERROR_DEFAULT - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_RETURN_VALUE - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_RETURN_VALUE_DEFAULT - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
CONF_TAGS - Static variable in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
ConfigurationOptions - Interface in org.elasticsearch.hadoop.cfg
Class providing the various Configuration parameters used by the Elasticsearch Hadoop integration.
configureInputJobProperties(TableDesc, Map<String, String>) - Method in class org.elasticsearch.hadoop.hive.EsStorageHandler
 
configureJobConf(TableDesc, JobConf) - Method in class org.elasticsearch.hadoop.hive.EsStorageHandler
 
configureOutputJobProperties(TableDesc, Map<String, String>) - Method in class org.elasticsearch.hadoop.hive.EsStorageHandler
 
configureTableJobProperties(TableDesc, Map<String, String>) - Method in class org.elasticsearch.hadoop.hive.EsStorageHandler
Deprecated.
configureTemplate(ElasticCommonSchema.TemplateBuilder) - Method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.BaseEventConverter
 
configureTemplate(ElasticCommonSchema.TemplateBuilder) - Method in interface org.elasticsearch.hadoop.handler.impl.elasticsearch.EventConverter
Perform some logic against the template builder in order to inject values before the template is built.
ConsolePrompt - Class in org.elasticsearch.hadoop.cli
 
ConsolePrompt() - Constructor for class org.elasticsearch.hadoop.cli.ConsolePrompt
 
constructCommitLogPath(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
Determines the location of the streaming commit log.
constructCommitLogPath(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
Determines the location of the streaming commit log.
containsEntry(String) - Method in class org.elasticsearch.hadoop.security.KeystoreWrapper
 
containsKey(Object) - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
containsValue(Object) - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
context() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
convert(I) - Method in class org.elasticsearch.hadoop.handler.impl.LogRenderer
 
convert(Object, BytesArray) - Method in class org.elasticsearch.hadoop.hive.HiveBytesConverter
 
convert(Object, BytesArray) - Method in class org.elasticsearch.hadoop.mr.WritableBytesConverter
 
convert(Object, BytesArray) - Method in class org.elasticsearch.hadoop.pig.PigBytesConverter
 
convert(Object, BytesArray) - Method in class org.elasticsearch.storm.serialization.StormTupleBytesConverter
 
convertToStruct(Mapping, Map<String, GeoField>, Settings) - Method in class org.elasticsearch.spark.sql.SchemaUtils$
 
convertToStruct(Mapping, Map<String, GeoField>, Settings) - Static method in class org.elasticsearch.spark.sql.SchemaUtils
 
copy() - Method in class org.elasticsearch.hadoop.cfg.CompositeSettings
 
copy() - Method in class org.elasticsearch.hadoop.cfg.FilteredSettings
 
copy() - Method in class org.elasticsearch.hadoop.cfg.HadoopSettings
 
copy() - Method in class org.elasticsearch.hadoop.cfg.PropertiesSettings
 
copy() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
copy() - Method in class org.elasticsearch.spark.cfg.SparkSettings
 
copy() - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
copy() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
Counter - Enum in org.elasticsearch.hadoop.mr
Enum used for representing the stats inside Hadoop.
create() - Static method in class org.elasticsearch.hadoop.handler.impl.AbortOnFailure
 
create(LogRenderer<I>) - Static method in class org.elasticsearch.hadoop.handler.impl.DropAndLog
 
create(Settings, EventConverter<I>) - Static method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
create(Settings) - Static method in class org.elasticsearch.hadoop.mr.security.HadoopUserProvider
 
create(Settings) - Static method in class org.elasticsearch.hadoop.security.UserProvider
 
createArray(FieldType) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
createArray(FieldType) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
createArray(FieldType) - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
createClient(Settings) - Method in class org.elasticsearch.hadoop.mr.security.EsTokenIdentifier.Renewer
 
createDate(long) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
createDate(String) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
createDate(long) - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
createKey() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.AbstractWritableEsInputRecordReader
 
createKey() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
createKey() - Method in class org.elasticsearch.hadoop.pig.EsPigInputFormat.AbstractPigEsInputRecordReader
 
createMap() - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
createMap() - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
createMap() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.elasticsearch.hadoop.pig.EsPigInputFormat
 
createRelation(SQLContext, Map<String, String>) - Method in class org.elasticsearch.spark.sql.DefaultSource
 
createRelation(SQLContext, Map<String, String>, StructType) - Method in class org.elasticsearch.spark.sql.DefaultSource
 
createRelation(SQLContext, SaveMode, Map<String, String>, Dataset<Row>) - Method in class org.elasticsearch.spark.sql.DefaultSource
 
createSink(SQLContext, Map<String, String>, Seq<String>, OutputMode) - Method in class org.elasticsearch.spark.sql.DefaultSource
 
createTokenFrom(EsToken) - Static method in class org.elasticsearch.hadoop.mr.security.EsTokenIdentifier
 
createValue() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
createValue() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.JsonWritableEsInputRecordReader
 
createValue() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.WritableEsInputRecordReader
 
createValue() - Method in class org.elasticsearch.hadoop.pig.EsPigInputFormat.PigEsInputRecordReader
 
createValue() - Method in class org.elasticsearch.hadoop.pig.EsPigInputFormat.PigJsonEsInputRecordReader
 
createValue(Object[]) - Method in class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
createValue(Object[]) - Method in class org.elasticsearch.spark.rdd.JavaEsRDDIterator
 
createValue(Object[]) - Method in class org.elasticsearch.spark.rdd.ScalaEsRDDIterator
 
createValue(Object[]) - Method in class org.elasticsearch.spark.sql.ScalaEsRowRDDIterator
 
credentialsRequired(Configuration) - Method in class org.elasticsearch.spark.deploy.yarn.security.EsServiceCredentialProvider
Given a configuration, check to see if tokens would be required.
credentialsRequired(SparkConf, Configuration) - Method in class org.elasticsearch.spark.deploy.yarn.security.EsServiceCredentialProvider
Given a configuration, check to see if tokens would be required.
currentArrayRowOrder() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
currentFieldIsGeo() - Method in interface org.elasticsearch.spark.sql.RowValueReader
 

D

DataFrameFieldExtractor - Class in org.elasticsearch.spark.sql
 
DataFrameFieldExtractor() - Constructor for class org.elasticsearch.spark.sql.DataFrameFieldExtractor
 
DataFrameValueWriter - Class in org.elasticsearch.spark.sql
 
DataFrameValueWriter(boolean) - Constructor for class org.elasticsearch.spark.sql.DataFrameValueWriter
 
DataFrameValueWriter() - Constructor for class org.elasticsearch.spark.sql.DataFrameValueWriter
 
DataFrameValueWriter$ - Class in org.elasticsearch.spark.sql
 
DataFrameValueWriter$() - Constructor for class org.elasticsearch.spark.sql.DataFrameValueWriter$
 
date(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
dateType() - Method in class org.elasticsearch.hadoop.hive.HiveValueReader
 
dateType() - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
deactivate() - Method in class org.elasticsearch.storm.EsSpout
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.elasticsearch.storm.EsBolt
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.elasticsearch.storm.EsSpout
 
defaultCompactInterval() - Method in class org.elasticsearch.spark.sql.streaming.EsSinkMetadataLog
 
DefaultSource - Class in org.elasticsearch.spark.sql
 
DefaultSource() - Constructor for class org.elasticsearch.spark.sql.DefaultSource
 
DefaultSource15 - Class in org.elasticsearch.spark.sql
 
DefaultSource15() - Constructor for class org.elasticsearch.spark.sql.DefaultSource15
 
deserialize(Writable) - Method in class org.elasticsearch.hadoop.hive.EsSerDe
 
detectRowInfo(Settings, StructType) - Method in class org.elasticsearch.spark.sql.SchemaUtils$
 
detectRowInfo(Settings, StructType) - Static method in class org.elasticsearch.spark.sql.SchemaUtils
 
discoverMapping(Settings) - Method in class org.elasticsearch.spark.sql.SchemaUtils$
 
discoverMapping(Settings) - Static method in class org.elasticsearch.spark.sql.SchemaUtils
 
discoverMappingAndGeoFields(Settings) - Method in class org.elasticsearch.spark.sql.SchemaUtils$
 
discoverMappingAndGeoFields(Settings) - Static method in class org.elasticsearch.spark.sql.SchemaUtils
 
doAs(PrivilegedAction<T>) - Method in class org.elasticsearch.hadoop.mr.security.HadoopUser
 
doAs(PrivilegedExceptionAction<T>) - Method in class org.elasticsearch.hadoop.mr.security.HadoopUser
 
doAs(PrivilegedAction<T>) - Method in class org.elasticsearch.hadoop.security.JdkUser
 
doAs(PrivilegedExceptionAction<T>) - Method in class org.elasticsearch.hadoop.security.JdkUser
 
doAs(PrivilegedAction<T>) - Method in interface org.elasticsearch.hadoop.security.User
Execute the given action as the user
doAs(PrivilegedExceptionAction<T>) - Method in interface org.elasticsearch.hadoop.security.User
Execute the given action as the user
doClose(Progressable) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsRecordWriter
 
doSaveToEs(RDD<?>, Map<String, String>, boolean) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
doSaveToEs(RDD<?>, Map<String, String>, boolean) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
doSaveToEs(DStream<?>, Map<String, String>, boolean) - Method in class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
doSaveToEs(DStream<?>, Map<String, String>, boolean) - Static method in class org.elasticsearch.spark.streaming.EsSparkStreaming
 
doubleType() - Method in class org.elasticsearch.hadoop.hive.HiveValueReader
 
doubleType() - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
doubleValue(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
doWrite(Object, Generator, String) - Method in class org.elasticsearch.spark.serialization.ScalaValueWriter
 
doWrite(Tuple, Generator, String) - Method in class org.elasticsearch.storm.serialization.StormValueWriter
 
DropAndLog<I extends Exceptional,O,C extends ErrorCollector<O>> - Class in org.elasticsearch.hadoop.handler.impl
 
DropAndLog(LogRenderer<I>) - Constructor for class org.elasticsearch.hadoop.handler.impl.DropAndLog
 

E

ElasticsearchHandler<I extends Exceptional,O,C extends ErrorCollector<O>> - Class in org.elasticsearch.hadoop.handler.impl.elasticsearch
Generic Error Handler that converts error events into JSON documents, and stores them in an Elasticsearch index.
ElasticsearchHandler(Settings, EventConverter<I>) - Constructor for class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
ElasticsearchRelation - Class in org.elasticsearch.spark.sql
 
ElasticsearchRelation(Map<String, String>, SQLContext, Option<StructType>) - Constructor for class org.elasticsearch.spark.sql.ElasticsearchRelation
 
ElasticsearchRelation$ - Class in org.elasticsearch.spark.sql
 
ElasticsearchRelation$() - Constructor for class org.elasticsearch.spark.sql.ElasticsearchRelation$
 
emptyAsNull() - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
endDoc() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
endGeoField() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
endLeadMetadata() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
endSource() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
endTrailMetadata() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
entrySet() - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
equals(Object) - Method in class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable
Are the two byte sequences equal?
equals(Object) - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
 
equals(Object) - Method in class org.elasticsearch.hadoop.security.EsToken
 
ErrorCollector<T> - Interface in org.elasticsearch.hadoop.handler
An interface for accepting modified information to be retried in the event of a recoverable failure.
ErrorHandler<I extends Exceptional,O,C extends ErrorCollector<O>> - Interface in org.elasticsearch.hadoop.handler
Handler interface to be notified of and handle recoverable errors during connector execution.
ES_BATCH_FLUSH_MANUAL - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Elasticsearch disable auto-flush on batch overflow
ES_BATCH_FLUSH_MANUAL_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_SIZE_BYTES - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Elasticsearch batch size given in bytes
ES_BATCH_SIZE_BYTES_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_SIZE_ENTRIES - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Elasticsearch batch size given in entries
ES_BATCH_SIZE_ENTRIES_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_WRITE_REFRESH - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Whether to trigger an index refresh after doing batch writing
ES_BATCH_WRITE_REFRESH_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_WRITE_RETRY_COUNT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
HTTP bulk retries
ES_BATCH_WRITE_RETRY_COUNT_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_WRITE_RETRY_LIMIT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_WRITE_RETRY_LIMIT_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_WRITE_RETRY_POLICY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_WRITE_RETRY_POLICY_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_WRITE_RETRY_POLICY_NONE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_WRITE_RETRY_POLICY_SIMPLE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_WRITE_RETRY_WAIT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_BATCH_WRITE_RETRY_WAIT_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_HEART_BEAT_LEAD - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Scroll fields
ES_HEART_BEAT_LEAD_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_HTTP_RETRIES - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_HTTP_RETRIES_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_HTTP_TIMEOUT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
HTTP connection timeout
ES_HTTP_TIMEOUT_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_INDEX_AUTO_CREATE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Index settings
ES_INDEX_AUTO_CREATE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_INDEX_READ_ALLOW_RED_STATUS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_INDEX_READ_ALLOW_RED_STATUS_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_INDEX_READ_MISSING_AS_EMPTY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_INDEX_READ_MISSING_AS_EMPTY_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_INGEST_PIPELINE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Ingest Node
ES_INGEST_PIPELINE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_INPUT_JSON - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_INPUT_JSON_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_INTERNAL_APP_ID() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_INTERNAL_APP_ID() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_INTERNAL_APP_NAME() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_INTERNAL_APP_NAME() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_INTERNAL_QUERY_NAME() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_INTERNAL_QUERY_NAME() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_INTERNAL_SESSION_CHECKPOINT_LOCATION() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_INTERNAL_SESSION_CHECKPOINT_LOCATION() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_INTERNAL_USER_CHECKPOINT_LOCATION() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_INTERNAL_USER_CHECKPOINT_LOCATION() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_KEYSTORE_LOCATION - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Secure Settings Keystore
ES_MAPPING_CONSTANT_AUTO_QUOTE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_CONSTANT_AUTO_QUOTE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_DATE_RICH_OBJECT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_DATE_RICH_OBJECT_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_DEFAULT_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Mapping types
ES_MAPPING_DEFAULT_INDEX_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_DEFAULT_INDEX_FORMATTER_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_EXCLUDE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_EXCLUDE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_ID - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_ID_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_INCLUDE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_INCLUDE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_INDEX_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_INDEX_FORMATTER_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_JOIN - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_JOIN_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_METADATA_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_PARAMS_DEFAULT_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_PARAMS_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_PARENT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_PARENT_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_ROUTING - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_ROUTING_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_TIMESTAMP - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_TIMESTAMP_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_TTL - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_TTL_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_VERSION - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_VERSION_EXTRACTOR_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_VERSION_TYPE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_VERSION_TYPE_EXTERNAL - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_VERSION_TYPE_EXTERNAL_GT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_VERSION_TYPE_EXTERNAL_GTE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_VERSION_TYPE_FORCE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAPPING_VERSION_TYPE_INTERNAL - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_MAX_DOCS_PER_PARTITION - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Input options
ES_NET_HTTP_AUTH_PASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_HTTP_AUTH_USER - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_HTTP_HEADER_PREFIX - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTP_HOST - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTP_PASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTP_PORT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTP_USE_SYSTEM_PROPS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTP_USE_SYSTEM_PROPS_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTP_USER - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTPS_HOST - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTPS_PASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTPS_PORT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTPS_USE_SYSTEM_PROPS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTPS_USE_SYSTEM_PROPS_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_HTTPS_USER - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_PROXY_SOCKS_HOST - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Deprecated.
ES_NET_PROXY_SOCKS_PASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Deprecated.
ES_NET_PROXY_SOCKS_PORT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Deprecated.
ES_NET_PROXY_SOCKS_USE_SYSTEM_PROPS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Deprecated.
ES_NET_PROXY_SOCKS_USE_SYSTEM_PROPS_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Deprecated.
ES_NET_PROXY_SOCKS_USER - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Deprecated.
ES_NET_SPNEGO_AUTH_ELASTICSEARCH_PRINCIPAL - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SPNEGO_AUTH_MUTUAL - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SPNEGO_AUTH_MUTUAL_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SSL_CERT_ALLOW_SELF_SIGNED - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SSL_CERT_ALLOW_SELF_SIGNED_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SSL_KEYSTORE_LOCATION - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SSL_KEYSTORE_PASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SSL_KEYSTORE_TYPE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SSL_KEYSTORE_TYPE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SSL_PROTOCOL - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SSL_PROTOCOL_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SSL_TRUST_STORE_LOCATION - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_SSL_TRUST_STORE_PASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_TRANSPORT_POOLING_EXPIRATION_TIMEOUT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Network options
ES_NET_TRANSPORT_POOLING_EXPIRATION_TIMEOUT_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_USE_SSL - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NET_USE_SSL_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NODES - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Elasticsearch host
ES_NODES_CLIENT_ONLY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Clients only
ES_NODES_CLIENT_ONLY_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NODES_DATA_ONLY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Data only
ES_NODES_DATA_ONLY_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NODES_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NODES_DISCOVERY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NODES_DISCOVERY_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NODES_INGEST_ONLY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Ingest only
ES_NODES_INGEST_ONLY_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NODES_PATH_PREFIX - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Elasticsearch prefix
ES_NODES_PATH_PREFIX_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NODES_RESOLVE_HOST_NAME - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_NODES_WAN_ONLY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
WAN only
ES_NODES_WAN_ONLY_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_OPERATION_CREATE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_OPERATION_DELETE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_OPERATION_INDEX - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_OPERATION_UPDATE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_OPERATION_UPSERT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_OUTPUT_JSON - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Output options
ES_OUTPUT_JSON_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_PORT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Elasticsearch port
ES_PORT_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_QUERY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_FIELD_AS_ARRAY_EXCLUDE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_FIELD_AS_ARRAY_INCLUDE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_FIELD_EMPTY_AS_NULL - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Field options
ES_READ_FIELD_EMPTY_AS_NULL_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_FIELD_EMPTY_AS_NULL_LEGACY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_FIELD_EXCLUDE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_FIELD_INCLUDE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_FIELD_VALIDATE_PRESENCE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_FIELD_VALIDATE_PRESENCE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_FIELD_VALIDATE_PRESENCE_LEGACY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_METADATA - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Metadata
ES_READ_METADATA_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_METADATA_FIELD - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_METADATA_FIELD_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_METADATA_VERSION - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_METADATA_VERSION_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_SHARD_PREFERENCE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Elasticsearch shard search preference
ES_READ_SHARD_PREFERENCE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_SOURCE_FILTER - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_UNMAPPED_FIELDS_IGNORE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_READ_UNMAPPED_FIELDS_IGNORE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_RESOURCE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Elasticsearch index
ES_RESOURCE_READ - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_RESOURCE_WRITE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_SCROLL_KEEPALIVE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Scroll keep-alive
ES_SCROLL_KEEPALIVE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_SCROLL_LIMIT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Scroll limit
ES_SCROLL_LIMIT_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_SCROLL_SIZE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Scroll size
ES_SCROLL_SIZE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_SECURITY_AUTHENTICATION - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Security options
ES_SECURITY_USER_PROVIDER_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_SERIALIZATION_READER_VALUE_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Value reader - setup automatically; can be overridden for custom types
ES_SERIALIZATION_WRITER_BYTES_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
JSON/Bytes writer - setup automatically; can be overridden for custom types
ES_SERIALIZATION_WRITER_VALUE_CLASS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Value writer - setup automatically; can be overridden for custom types
ES_SINK_LOG_CLEANUP_DELAY() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_SINK_LOG_CLEANUP_DELAY() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_SINK_LOG_CLEANUP_DELAY_DEFAULT() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_SINK_LOG_CLEANUP_DELAY_DEFAULT() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_SINK_LOG_COMPACT_INTERVAL() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_SINK_LOG_COMPACT_INTERVAL() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_SINK_LOG_COMPACT_INTERVAL_DEFAULT() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_SINK_LOG_COMPACT_INTERVAL_DEFAULT() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_SINK_LOG_DELETION() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_SINK_LOG_DELETION() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_SINK_LOG_DELETION_DEFAULT() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_SINK_LOG_DELETION_DEFAULT() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_SINK_LOG_ENABLE() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_SINK_LOG_ENABLE() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_SINK_LOG_ENABLE_DEFAULT() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_SINK_LOG_ENABLE_DEFAULT() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_SINK_LOG_PATH() - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
ES_SINK_LOG_PATH() - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
ES_SPARK_DATAFRAME_WRITE_NULL_VALUES - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Technology Specific
ES_SPARK_DATAFRAME_WRITE_NULL_VALUES_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_STORM_BOLT_ACK - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_BOLT_ACK_DEFAULT - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_BOLT_FLUSH_ENTRIES_SIZE - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_BOLT_TICK_TUPLE_FLUSH - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_BOLT_TICK_TUPLE_FLUSH_DEFAULT - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_SPOUT_FIELDS - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_SPOUT_FIELDS_DEFAULT - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_SPOUT_RELIABLE - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_SPOUT_RELIABLE_DEFAULT - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_SPOUT_RELIABLE_QUEUE_SIZE - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_SPOUT_RELIABLE_QUEUE_SIZE_DEFAULT - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_SPOUT_RELIABLE_RETRIES_PER_TUPLE - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_SPOUT_RELIABLE_RETRIES_PER_TUPLE_DEFAULT - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_SPOUT_RELIABLE_TUPLE_FAILURE_HANDLE - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_STORM_SPOUT_RELIABLE_TUPLE_FAILURE_HANDLE_DEFAULT - Static variable in interface org.elasticsearch.storm.cfg.StormConfigurationOptions
 
ES_UPDATE_RETRY_ON_CONFLICT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_UPDATE_RETRY_ON_CONFLICT_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_UPDATE_SCRIPT_FILE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_UPDATE_SCRIPT_INLINE - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_UPDATE_SCRIPT_LANG - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_UPDATE_SCRIPT_LEGACY - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_UPDATE_SCRIPT_PARAMS - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_UPDATE_SCRIPT_PARAMS_JSON - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_UPDATE_SCRIPT_STORED - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
ES_WRITE_OPERATION - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
Operation types
ES_WRITE_OPERATION_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.ConfigurationOptions
 
EsBolt - Class in org.elasticsearch.storm
 
EsBolt(String) - Constructor for class org.elasticsearch.storm.EsBolt
 
EsBolt(String, boolean) - Constructor for class org.elasticsearch.storm.EsBolt
 
EsBolt(String, Map) - Constructor for class org.elasticsearch.storm.EsBolt
 
esCfg() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDD
 
EsClusterInfoSelector - Class in org.elasticsearch.storm.security
Storm bolts and spouts don't actually ever run anything on the driver side of a topology submission.
EsClusterInfoSelector() - Constructor for class org.elasticsearch.storm.security.EsClusterInfoSelector
 
EsCommitProtocol - Class in org.elasticsearch.spark.sql.streaming
Defines job-side and task-side logic for committing batches of writes to Elasticsearch for Spark Structured Streaming
EsCommitProtocol(MetadataLog<EsSinkStatus[]>) - Constructor for class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
 
esCount() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDD
 
EsDataFrameWriter - Class in org.elasticsearch.spark.sql
 
EsDataFrameWriter(StructType, String) - Constructor for class org.elasticsearch.spark.sql.EsDataFrameWriter
 
esDF(SQLContext) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SQLContext, String) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SQLContext, String, String) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SQLContext, Map<String, String>) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SQLContext, String, Map<String, String>) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SQLContext, String, String, Map<String, String>) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SparkSession) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SparkSession, String) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SparkSession, String, String) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SparkSession, Map<String, String>) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SparkSession, String, Map<String, String>) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SparkSession, String, String, Map<String, String>) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
esDF(SQLContext) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SQLContext, String) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SQLContext, String, String) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SQLContext, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SQLContext, String, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SQLContext, String, String, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SparkSession) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SparkSession, String) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SparkSession, String, String) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SparkSession, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SparkSession, String, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SparkSession, String, String, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
esDF(SQLContext) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SQLContext, String) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SQLContext, String, String) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SQLContext, Map<String, String>) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SQLContext, String, String, Map<String, String>) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SQLContext, String, Map<String, String>) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SparkSession) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SparkSession, String) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SparkSession, String, String) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SparkSession, Map<String, String>) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SparkSession, String, String, Map<String, String>) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SparkSession, String, Map<String, String>) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
esDF(SQLContext) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SQLContext, String) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SQLContext, String, String) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SQLContext, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SQLContext, String, String, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SQLContext, String, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SparkSession) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SparkSession, String) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SparkSession, String, String) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SparkSession, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SparkSession, String, String, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
esDF(SparkSession, String, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
EsHadoopAbortHandlerException - Exception in org.elasticsearch.hadoop.handler
Denotes that a handler has decided to abort the job on a potentially retryable value.
EsHadoopAbortHandlerException(String, Throwable) - Constructor for exception org.elasticsearch.hadoop.handler.EsHadoopAbortHandlerException
 
EsHadoopAbortHandlerException(String) - Constructor for exception org.elasticsearch.hadoop.handler.EsHadoopAbortHandlerException
 
EsHadoopException - Exception in org.elasticsearch.hadoop
Base class for Elasticsearch Hadoop exceptions.
EsHadoopException() - Constructor for exception org.elasticsearch.hadoop.EsHadoopException
 
EsHadoopException(String, Throwable) - Constructor for exception org.elasticsearch.hadoop.EsHadoopException
 
EsHadoopException(String) - Constructor for exception org.elasticsearch.hadoop.EsHadoopException
 
EsHadoopException(Throwable) - Constructor for exception org.elasticsearch.hadoop.EsHadoopException
 
EsHadoopIllegalArgumentException - Exception in org.elasticsearch.hadoop
 
EsHadoopIllegalArgumentException() - Constructor for exception org.elasticsearch.hadoop.EsHadoopIllegalArgumentException
 
EsHadoopIllegalArgumentException(String, Throwable) - Constructor for exception org.elasticsearch.hadoop.EsHadoopIllegalArgumentException
 
EsHadoopIllegalArgumentException(String) - Constructor for exception org.elasticsearch.hadoop.EsHadoopIllegalArgumentException
 
EsHadoopIllegalArgumentException(Throwable) - Constructor for exception org.elasticsearch.hadoop.EsHadoopIllegalArgumentException
 
EsHadoopIllegalStateException - Exception in org.elasticsearch.hadoop
 
EsHadoopIllegalStateException() - Constructor for exception org.elasticsearch.hadoop.EsHadoopIllegalStateException
 
EsHadoopIllegalStateException(String, Throwable) - Constructor for exception org.elasticsearch.hadoop.EsHadoopIllegalStateException
 
EsHadoopIllegalStateException(String) - Constructor for exception org.elasticsearch.hadoop.EsHadoopIllegalStateException
 
EsHadoopIllegalStateException(Throwable) - Constructor for exception org.elasticsearch.hadoop.EsHadoopIllegalStateException
 
EsHadoopSecurityException - Exception in org.elasticsearch.hadoop.security
 
EsHadoopSecurityException() - Constructor for exception org.elasticsearch.hadoop.security.EsHadoopSecurityException
 
EsHadoopSecurityException(String) - Constructor for exception org.elasticsearch.hadoop.security.EsHadoopSecurityException
 
EsHadoopSecurityException(String, Throwable) - Constructor for exception org.elasticsearch.hadoop.security.EsHadoopSecurityException
 
EsHadoopSecurityException(Throwable) - Constructor for exception org.elasticsearch.hadoop.security.EsHadoopSecurityException
 
EsHadoopUnsupportedOperationException - Exception in org.elasticsearch.hadoop
Denotes an operation that is not allowed to be performed, often due to the feature support of the version of Elasticsearch being used.
EsHadoopUnsupportedOperationException() - Constructor for exception org.elasticsearch.hadoop.EsHadoopUnsupportedOperationException
 
EsHadoopUnsupportedOperationException(String, Throwable) - Constructor for exception org.elasticsearch.hadoop.EsHadoopUnsupportedOperationException
 
EsHadoopUnsupportedOperationException(String) - Constructor for exception org.elasticsearch.hadoop.EsHadoopUnsupportedOperationException
 
EsHadoopUnsupportedOperationException(Throwable) - Constructor for exception org.elasticsearch.hadoop.EsHadoopUnsupportedOperationException
 
EsHiveInputFormat - Class in org.elasticsearch.hadoop.hive
Hive specific InputFormat.
EsHiveInputFormat() - Constructor for class org.elasticsearch.hadoop.hive.EsHiveInputFormat
 
EsHiveOutputFormat - Class in org.elasticsearch.hadoop.hive
Hive specific OutputFormat.
EsHiveOutputFormat() - Constructor for class org.elasticsearch.hadoop.hive.EsHiveOutputFormat
 
EsInputFormat<K,V> - Class in org.elasticsearch.hadoop.mr
ElasticSearch InputFormat for streaming data (typically based on a query) from ElasticSearch.
EsInputFormat() - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat
 
EsInputFormat.AbstractWritableEsInputRecordReader<V> - Class in org.elasticsearch.hadoop.mr
 
EsInputFormat.EsInputRecordReader<K,V> - Class in org.elasticsearch.hadoop.mr
 
EsInputFormat.EsInputSplit - Class in org.elasticsearch.hadoop.mr
 
EsInputFormat.JsonWritableEsInputRecordReader - Class in org.elasticsearch.hadoop.mr
 
EsInputFormat.WritableEsInputRecordReader - Class in org.elasticsearch.hadoop.mr
 
EsInputRecordReader() - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
EsInputRecordReader(InputSplit, Configuration, Reporter) - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
EsInputSplit() - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputSplit
 
EsInputSplit(PartitionDefinition) - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputSplit
 
esJsonRDD(JavaSparkContext) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
esJsonRDD(JavaSparkContext, String) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
esJsonRDD(JavaSparkContext, String, String) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
esJsonRDD(JavaSparkContext, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
esJsonRDD(JavaSparkContext) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
esJsonRDD(JavaSparkContext, String) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
esJsonRDD(JavaSparkContext, String, String) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
esJsonRDD(JavaSparkContext, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
esJsonRDD(SparkContext) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esJsonRDD(SparkContext, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esJsonRDD(SparkContext, String) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esJsonRDD(SparkContext, String, String) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esJsonRDD(SparkContext, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esJsonRDD(SparkContext, String, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esJsonRDD(SparkContext) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
esJsonRDD(SparkContext, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
esJsonRDD(SparkContext, String) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
esJsonRDD(SparkContext, String, String) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
esJsonRDD(SparkContext, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
esJsonRDD(SparkContext, String, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
EsMapReduceUtil - Class in org.elasticsearch.hadoop.mr
Utility functions for setting up Map Reduce Jobs to read and write from Elasticsearch.
EsOldAPIOutputCommitter() - Constructor for class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOldAPIOutputCommitter
 
EsOutputCommitter() - Constructor for class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOutputCommitter
 
EsOutputFormat - Class in org.elasticsearch.hadoop.mr
ElasticSearch OutputFormat (old and new API) for adding data to an index inside ElasticSearch.
EsOutputFormat() - Constructor for class org.elasticsearch.hadoop.mr.EsOutputFormat
 
EsOutputFormat.EsOldAPIOutputCommitter - Class in org.elasticsearch.hadoop.mr
 
EsOutputFormat.EsOutputCommitter - Class in org.elasticsearch.hadoop.mr
 
EsOutputFormat.EsRecordWriter - Class in org.elasticsearch.hadoop.mr
 
EsPartition - Class in org.elasticsearch.spark.rdd
 
EsPartition(int, int, PartitionDefinition) - Constructor for class org.elasticsearch.spark.rdd.EsPartition
 
esPartition() - Method in class org.elasticsearch.spark.rdd.EsPartition
 
esPartitions() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDD
 
EsPigInputFormat - Class in org.elasticsearch.hadoop.pig
 
EsPigInputFormat() - Constructor for class org.elasticsearch.hadoop.pig.EsPigInputFormat
 
EsPigInputFormat.AbstractPigEsInputRecordReader<V> - Class in org.elasticsearch.hadoop.pig
 
EsPigInputFormat.PigEsInputRecordReader - Class in org.elasticsearch.hadoop.pig
 
EsPigInputFormat.PigJsonEsInputRecordReader - Class in org.elasticsearch.hadoop.pig
 
esRDD(JavaSparkContext) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
esRDD(JavaSparkContext, String) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
esRDD(JavaSparkContext, String, String) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
esRDD(JavaSparkContext, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
esRDD(JavaSparkContext) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
esRDD(JavaSparkContext, String) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
esRDD(JavaSparkContext, String, String) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
esRDD(JavaSparkContext, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
esRDD(SparkContext) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esRDD(SparkContext, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esRDD(SparkContext, String) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esRDD(SparkContext, String, String) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esRDD(SparkContext, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esRDD(SparkContext, String, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
esRDD(SparkContext) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
esRDD(SparkContext, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
esRDD(SparkContext, String) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
esRDD(SparkContext, String, String) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
esRDD(SparkContext, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
esRDD(SparkContext, String, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
EsRDDWriter<T> - Class in org.elasticsearch.spark.rdd
 
EsRDDWriter(String, boolean, ClassTag<T>) - Constructor for class org.elasticsearch.spark.rdd.EsRDDWriter
 
EsRDDWriter$ - Class in org.elasticsearch.spark.rdd
 
EsRDDWriter$() - Constructor for class org.elasticsearch.spark.rdd.EsRDDWriter$
 
EsRecordWriter(Configuration, Progressable) - Constructor for class org.elasticsearch.hadoop.mr.EsOutputFormat.EsRecordWriter
 
EsSerDe - Class in org.elasticsearch.hadoop.hive
 
EsSerDe() - Constructor for class org.elasticsearch.hadoop.hive.EsSerDe
 
EsServiceCredentialProvider - Class in org.elasticsearch.spark.deploy.yarn.security
A provider interface in Spark's Yarn library that obtains tokens for an application.
EsServiceCredentialProvider() - Constructor for class org.elasticsearch.spark.deploy.yarn.security.EsServiceCredentialProvider
 
EsSinkMetadataLog - Class in org.elasticsearch.spark.sql.streaming
Provides logic for managing batch ID committing as well as cleaning up state between batch executions for the EsSparkSqlStreamingSink
EsSinkMetadataLog(Settings, SparkSession, String) - Constructor for class org.elasticsearch.spark.sql.streaming.EsSinkMetadataLog
 
EsSinkMetadataLog$ - Class in org.elasticsearch.spark.sql.streaming
Companion object for EsSinkMetadataLog.
EsSinkMetadataLog$() - Constructor for class org.elasticsearch.spark.sql.streaming.EsSinkMetadataLog$
 
EsSinkStatus - Class in org.elasticsearch.spark.sql.streaming
An envelope of metadata that is stored in the commit log.
EsSinkStatus(int, long, String, long) - Constructor for class org.elasticsearch.spark.sql.streaming.EsSinkStatus
 
EsSinkStatus$ - Class in org.elasticsearch.spark.sql.streaming
 
EsSinkStatus$() - Constructor for class org.elasticsearch.spark.sql.streaming.EsSinkStatus$
 
EsSpark - Class in org.elasticsearch.spark.rdd
 
EsSpark() - Constructor for class org.elasticsearch.spark.rdd.EsSpark
 
EsSpark$ - Class in org.elasticsearch.spark.rdd
 
EsSpark$() - Constructor for class org.elasticsearch.spark.rdd.EsSpark$
 
EsSparkSQL - Class in org.elasticsearch.spark.sql
 
EsSparkSQL() - Constructor for class org.elasticsearch.spark.sql.EsSparkSQL
 
EsSparkSQL$ - Class in org.elasticsearch.spark.sql
 
EsSparkSQL$() - Constructor for class org.elasticsearch.spark.sql.EsSparkSQL$
 
EsSparkSqlStreamingSink - Class in org.elasticsearch.spark.sql.streaming
Sink for writing Spark Structured Streaming Queries to an Elasticsearch cluster.
EsSparkSqlStreamingSink(SparkSession, Settings) - Constructor for class org.elasticsearch.spark.sql.streaming.EsSparkSqlStreamingSink
 
EsSparkStreaming - Class in org.elasticsearch.spark.streaming
 
EsSparkStreaming() - Constructor for class org.elasticsearch.spark.streaming.EsSparkStreaming
 
EsSparkStreaming$ - Class in org.elasticsearch.spark.streaming
 
EsSparkStreaming$() - Constructor for class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
EsSpout - Class in org.elasticsearch.storm
 
EsSpout(String) - Constructor for class org.elasticsearch.storm.EsSpout
 
EsSpout(String, String) - Constructor for class org.elasticsearch.storm.EsSpout
 
EsSpout(String, Map) - Constructor for class org.elasticsearch.storm.EsSpout
 
EsSpout(String, String, Map) - Constructor for class org.elasticsearch.storm.EsSpout
 
EsStorage - Class in org.elasticsearch.hadoop.pig
Pig storage for reading and writing data into an ElasticSearch index.
EsStorage() - Constructor for class org.elasticsearch.hadoop.pig.EsStorage
 
EsStorage(String...) - Constructor for class org.elasticsearch.hadoop.pig.EsStorage
 
EsStorageHandler - Class in org.elasticsearch.hadoop.hive
Hive storage for writing data into an ElasticSearch index.
EsStorageHandler() - Constructor for class org.elasticsearch.hadoop.hive.EsStorageHandler
 
EsStreamQueryWriter - Class in org.elasticsearch.spark.sql.streaming
Takes in iterator of InternalRow objects from a partition of data, writes it to Elasticsearch, and manages the streaming commit protocol.
EsStreamQueryWriter(String, StructType, EsCommitProtocol) - Constructor for class org.elasticsearch.spark.sql.streaming.EsStreamQueryWriter
 
EsToken - Class in org.elasticsearch.hadoop.security
Stores token authentication information for an Elasticsearch user.
EsToken(String, String, String, long, String, EsMajorVersion) - Constructor for class org.elasticsearch.hadoop.security.EsToken
 
EsToken(DataInput) - Constructor for class org.elasticsearch.hadoop.security.EsToken
 
EsTokenIdentifier - Class in org.elasticsearch.hadoop.mr.security
The Hadoop Token Identifier for any generic token that contains an EsToken within it.
EsTokenIdentifier() - Constructor for class org.elasticsearch.hadoop.mr.security.EsTokenIdentifier
 
EsTokenIdentifier.Renewer - Class in org.elasticsearch.hadoop.mr.security
 
EventConverter<E extends Exceptional> - Interface in org.elasticsearch.hadoop.handler.impl.elasticsearch
Given a failure event that extends Exceptional, provide a mechanism for transforming its fields into an ECS document.
Exceptional - Interface in org.elasticsearch.hadoop.handler
Any object that carries with it an internal Exception that details some kind of faulty operation or data.
excludeFilter(String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
excludeSource() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
execTimeMillis() - Method in class org.elasticsearch.spark.sql.streaming.EsSinkStatus
 
execute(Prompt, String[]) - Static method in class org.elasticsearch.hadoop.cli.Keytool
 
execute(Tuple) - Method in class org.elasticsearch.storm.EsBolt
 
executionStart() - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
 
extractField(Object) - Method in class org.elasticsearch.hadoop.hive.HiveFieldExtractor
 
extractField(Object) - Method in class org.elasticsearch.hadoop.pig.PigFieldExtractor
 
extractField(Object) - Method in class org.elasticsearch.spark.serialization.ScalaMapFieldExtractor
 
extractField(Object) - Method in class org.elasticsearch.spark.sql.DataFrameFieldExtractor
 
extractField(Object) - Method in class org.elasticsearch.storm.serialization.StormTupleFieldExtractor
 

F

fail(Object) - Method in class org.elasticsearch.storm.EsSpout
 
fieldExtractor() - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
fieldExtractor() - Method in class org.elasticsearch.spark.sql.EsDataFrameWriter
 
fieldExtractor() - Method in class org.elasticsearch.spark.sql.streaming.EsStreamQueryWriter
 
fieldNames - Variable in class org.elasticsearch.hadoop.hive.HiveFieldExtractor
 
FieldPresenceValidation - Enum in org.elasticsearch.hadoop.cfg
 
fileCleanupDelayMs() - Method in class org.elasticsearch.spark.sql.streaming.EsSinkMetadataLog
 
FilteredSettings - Class in org.elasticsearch.hadoop.cfg
Filtered settings are used for masking and hiding configuration values by key prefix.
finished() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
floatValue(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 

G

generateEvent(E, MessageTemplate) - Method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.BaseEventConverter
 
generateEvent(E, MessageTemplate) - Method in interface org.elasticsearch.hadoop.handler.impl.elasticsearch.EventConverter
Converts an event into an ECS compliant document using the given message template.
get(Stats) - Method in enum org.elasticsearch.hadoop.mr.Counter
 
get(Object) - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
get(String) - Static method in enum org.elasticsearch.hadoop.security.AuthenticationMethod
Look up an AuthenticationMethod based on the given value of a setting.
get(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
get(long) - Method in class org.elasticsearch.spark.sql.streaming.NullMetadataLog
 
get(Option<Object>, Option<Object>) - Method in class org.elasticsearch.spark.sql.streaming.NullMetadataLog
 
getAllEsTokens() - Method in class org.elasticsearch.hadoop.mr.security.HadoopUser
 
getAllEsTokens() - Method in class org.elasticsearch.hadoop.security.JdkUser
 
getAllEsTokens() - Method in interface org.elasticsearch.hadoop.security.User
 
getApiKey() - Method in class org.elasticsearch.hadoop.security.EsToken
 
getAppId(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
The ID of the current Spark application, if set
getAppId(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
The ID of the current Spark application, if set
getAppName(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
The name of the current Spark application, if set
getAppName(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
The name of the current Spark application, if set
getAvailableMethods() - Static method in enum org.elasticsearch.hadoop.security.AuthenticationMethod
 
getBatchFlushManual() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getBatchRefreshAfterWrite() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getBatchSizeInBytes() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getBatchSizeInEntries() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getBatchWriteRetryCount() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getBatchWriteRetryLimit() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getBatchWriteRetryPolicy() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getBatchWriteRetryWait() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getBoolean(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
getByte(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
getBytes() - Method in class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable
 
getClusterInfoOrNull() - Method in class org.elasticsearch.hadoop.cfg.Settings
Get the internal cluster name and version or null if not present in the settings
getClusterInfoOrThrow() - Method in class org.elasticsearch.hadoop.cfg.Settings
Get the internal cluster name and version or throw an IllegalArgumentException if not present
getClusterInfoOrUnnamedLatest() - Method in class org.elasticsearch.hadoop.cfg.Settings
Deprecated.
This is a dangerous method to use, because it assumes that you care about which cluster you are working with, but the info you receive from this call may not be accurate, and thus, cannot be trusted to let you make accurate decisions about the ES cluster you are speaking with. Prefer to use the Settings.getClusterInfoOrThrow() instead.
getClusterName() - Method in class org.elasticsearch.hadoop.security.EsToken
 
getComponentConfiguration() - Method in class org.elasticsearch.storm.EsBolt
 
getComponentConfiguration() - Method in class org.elasticsearch.storm.EsSpout
 
getContent() - Method in class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable
 
getCurrentKey() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
getCurrentValue() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
getDataFrameWriteNullValues() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getDefaultCompactInterval(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
getDefaultCompactInterval(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
getDouble(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
getEsToken(String) - Method in class org.elasticsearch.hadoop.mr.security.HadoopUser
 
getEsToken(String) - Method in class org.elasticsearch.hadoop.security.JdkUser
 
getEsToken(String) - Method in interface org.elasticsearch.hadoop.security.User
 
getException() - Method in interface org.elasticsearch.hadoop.handler.Exceptional
 
getException() - Method in class org.elasticsearch.hadoop.handler.impl.BaseExceptional
 
getExcludeSource() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getExpirationTime() - Method in class org.elasticsearch.hadoop.security.EsToken
 
getFeatures() - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
getFileCleanupDelayMs(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
The number of milliseconds to wait before cleaning up compacted log files
getFileCleanupDelayMs(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
The number of milliseconds to wait before cleaning up compacted log files
getFileOutputFormatDir(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getFileSystem(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getFloat(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
getHandlerPropertyName() - Method in class org.elasticsearch.hadoop.handler.impl.AbstractHandlerLoader
 
getHandlersPropertyName() - Method in class org.elasticsearch.hadoop.handler.impl.AbstractHandlerLoader
 
getHeartBeatLead() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getHiveRecordWriter(JobConf, Path, Class, boolean, Properties, Progressable) - Method in class org.elasticsearch.hadoop.hive.EsHiveOutputFormat
 
getHttpRetries() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getHttpTimeout() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getId() - Method in class org.elasticsearch.hadoop.security.EsToken
 
getIndexAutoCreate() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getIndexReadAllowRedStatus() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getIndexReadMissingAsEmpty() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getIngestPipeline() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getInputAsJson() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getInputFormat() - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
getInputFormatClass() - Method in class org.elasticsearch.hadoop.hive.EsStorageHandler
 
getInt(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
getInternalVersionOrLatest() - Method in class org.elasticsearch.hadoop.cfg.Settings
Deprecated.
This is kind of a dangerous method to use, because it assumes that you care about which version you are working with, but the version you receive from this call may not be accurate, and thus, cannot be trusted to let you make accurate decisions about the version of ES you are speaking with. Prefer to use the Settings.getInternalVersionOrThrow() instead.
getInternalVersionOrThrow() - Method in class org.elasticsearch.hadoop.cfg.Settings
Get the internal version or throw an IllegalArgumentException if not present
getIsDeletingExpiredLog(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
getIsDeletingExpiredLog(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
getJobTracker(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getKerberosPrincipal() - Method in class org.elasticsearch.hadoop.mr.security.HadoopUser
 
getKerberosPrincipal() - Method in class org.elasticsearch.hadoop.security.JdkUser
 
getKerberosPrincipal() - Method in interface org.elasticsearch.hadoop.security.User
 
getKind() - Method in class org.elasticsearch.hadoop.mr.security.EsTokenIdentifier
 
getLatest() - Method in class org.elasticsearch.spark.sql.streaming.NullMetadataLog
 
getLength() - Method in class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable
 
getLength() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputSplit
 
getLocations() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputSplit
 
getLogger() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
getLogger() - Method in class org.elasticsearch.spark.rdd.JavaEsRDDIterator
 
getLogger() - Method in class org.elasticsearch.spark.rdd.ScalaEsRDDIterator
 
getLogger() - Method in class org.elasticsearch.spark.sql.ScalaEsRowRDDIterator
 
getLogPath(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
The log path, if set, is the complete log path to be used for the commit log.
getLogPath(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
The log path, if set, is the complete log path to be used for the commit log.
getLong(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
getMajorVersion() - Method in class org.elasticsearch.hadoop.security.EsToken
 
getMappingConstantAutoQuote() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingDateRich() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingDefaultClassExtractor() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingExcludes() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingId() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingIdExtractorClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingIncludes() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingIndexExtractorClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingIndexFormatterClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingJoin() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingJoinExtractorClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingMetadataExtractorClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingParamsExtractorClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingParent() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingParentExtractorClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingRouting() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingRoutingExtractorClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingTimestamp() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingTimestampExtractorClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingTtl() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingTtlExtractorClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingVersion() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingVersionExtractorClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMappingVersionType() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMapValueClass(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getMaxDocsPerPartition() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getMetaHook() - Method in class org.elasticsearch.hadoop.hive.EsStorageHandler
 
getName() - Method in class org.elasticsearch.hadoop.security.EsToken
 
getNetworkHttpAuthPass() - Method in class org.elasticsearch.hadoop.cfg.Settings
Deprecated.
getNetworkHttpAuthUser() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkHttpsUseSystemProperties() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkHttpUseSystemProperties() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkProxyHttpHost() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkProxyHttpPass() - Method in class org.elasticsearch.hadoop.cfg.Settings
Deprecated.
getNetworkProxyHttpPort() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkProxyHttpsHost() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkProxyHttpsPass() - Method in class org.elasticsearch.hadoop.cfg.Settings
Deprecated.
getNetworkProxyHttpsPort() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkProxyHttpsUser() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkProxyHttpUser() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkProxySocksHost() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkProxySocksPass() - Method in class org.elasticsearch.hadoop.cfg.Settings
Deprecated.
getNetworkProxySocksPort() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkProxySocksUser() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkSocksUseSystemProperties() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkSpnegoAuthElasticsearchPrincipal() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkSpnegoAuthMutual() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkSSLAcceptSelfSignedCert() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkSSLEnabled() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkSSLKeyStoreLocation() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkSSLKeyStorePass() - Method in class org.elasticsearch.hadoop.cfg.Settings
Deprecated.
getNetworkSSLKeyStoreType() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkSSLProtocol() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkSSLTrustStoreLocation() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNetworkSSLTrustStorePass() - Method in class org.elasticsearch.hadoop.cfg.Settings
Deprecated.
getNext() - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
getNimbusCredentialRenewersFrequencySeconds() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
getNodes() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNodesClientOnly() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNodesDataOnly() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNodesDiscovery() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNodesIngestOnly() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNodesPathPrefix() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNodesResolveHostnames() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getNodesWANOnly() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getObject() - Method in class org.elasticsearch.hadoop.hive.HiveType
 
getObjectInspector() - Method in class org.elasticsearch.hadoop.hive.EsSerDe
 
getObjectInspector() - Method in class org.elasticsearch.hadoop.hive.HiveType
 
getOperation() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getOutputAsJson() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getOutputCommitter(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.MultiOutputFormat
 
getOutputCommitterClass(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getOutputFormat() - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
getOutputFormatClass() - Method in class org.elasticsearch.hadoop.hive.EsStorageHandler
 
getPartition() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputSplit
 
getPartitionKeys(String, Job) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
getPartitions() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDD
 
getPort() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getPos() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
getPreferredLocations(Partition) - Method in class org.elasticsearch.spark.rdd.AbstractEsRDD
 
getProgress() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
getProperty(String) - Method in class org.elasticsearch.hadoop.cfg.CompositeSettings
 
getProperty(String) - Method in class org.elasticsearch.hadoop.cfg.FilteredSettings
 
getProperty(String) - Method in class org.elasticsearch.hadoop.cfg.HadoopSettings
 
getProperty(String) - Method in class org.elasticsearch.hadoop.cfg.PropertiesSettings
 
getProperty(String, String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getProperty(String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getProperty(String) - Method in class org.elasticsearch.spark.cfg.SparkSettings
 
getProperty(String) - Method in class org.elasticsearch.storm.cfg.StormSettings
 
getQuery() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getQueryName(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
The name of the current Spark Streaming Query, if set
getQueryName(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
The name of the current Spark Streaming Query, if set
getRawEvent(E) - Method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.BaseEventConverter
Visible for testing
getReadFieldAsArrayExclude() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getReadFieldAsArrayInclude() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getReadFieldEmptyAsNull() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getReadFieldExclude() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getReadFieldExistanceValidation() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getReadFieldInclude() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getReadMappingMissingFieldsIgnore() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getReadMetadata() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getReadMetadataField() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getReadMetadataVersion() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getReadSourceFilter() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getRealUserProvider() - Method in class org.elasticsearch.hadoop.mr.security.HadoopUser
 
getRealUserProvider() - Method in class org.elasticsearch.hadoop.security.JdkUser
 
getRealUserProvider() - Method in interface org.elasticsearch.hadoop.security.User
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.elasticsearch.hadoop.hive.EsHiveInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.elasticsearch.hadoop.pig.EsPigInputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.elasticsearch.hadoop.mr.MultiOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.MultiOutputFormat
 
getReduceTasks(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getResource() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getResourceRead() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getResourceWrite() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getRowInfo(Settings) - Method in class org.elasticsearch.spark.sql.SchemaUtils$
 
getRowInfo(Settings) - Static method in class org.elasticsearch.spark.sql.SchemaUtils
 
getSchema(String, Job) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
getSchema() - Method in class org.elasticsearch.hadoop.pig.PigTuple
 
getScrollFields() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getScrollKeepAlive() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getScrollLimit() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getScrollSize() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getSecureProperty(String) - Method in class org.elasticsearch.hadoop.security.SecureSettings
 
getSecureSetting(String) - Method in class org.elasticsearch.hadoop.security.KeystoreWrapper
 
getSecurityAuthenticationMethod() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getSecurityUserProviderClass() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getSerDeClass() - Method in class org.elasticsearch.hadoop.hive.EsStorageHandler
 
getSerDeStats() - Method in class org.elasticsearch.hadoop.hive.EsSerDe
 
getSerializedClass() - Method in class org.elasticsearch.hadoop.hive.EsSerDe
 
getSerializerBytesConverterClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getSerializerValueReaderClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getSerializerValueWriterClassName() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getSessionCheckpointLocation(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
The name of the default session checkpoint location, if set
getSessionCheckpointLocation(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
The name of the default session checkpoint location, if set
getSettings() - Method in class org.elasticsearch.hadoop.handler.impl.AbstractHandlerLoader
 
getSettings() - Method in class org.elasticsearch.hadoop.security.UserProvider
 
getSettingsView(String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getShardPreference() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getShort(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
getSinkLogEnabled(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
Determines if we should use the commit log for writes, or if we should go without one.
getSinkLogEnabled(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
Determines if we should use the commit log for writes, or if we should go without one.
getSpeculativeMap(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getSpeculativeReduce(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getSplits(JobConf, int) - Method in class org.elasticsearch.hadoop.hive.EsHiveInputFormat
 
getSplits(JobContext) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat
 
getSplits(JobConf, int) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat
 
getStatistics(String, Job) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
getStormBoltAck() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
getStormBulkSize() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
getStormSpoutFields() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
getStormSpoutReliable() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
getStormSpoutReliableQueueSize() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
getStormSpoutReliableRetriesPerTuple() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
getStormSpoutReliableTupleFailureHandling() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
getStormTickTupleFlush() - Method in class org.elasticsearch.storm.cfg.StormSettings
 
getString(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
getTaskAttemptId(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getTaskId(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getTaskID(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getTaskTimeout(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
getTimestamp(E) - Method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.BaseEventConverter
Visible for testing
getTransportPoolingExpirationTimeout() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getTuple() - Method in class org.elasticsearch.hadoop.pig.PigTuple
 
getUpdateRetryOnConflict() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getUpdateScript() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getUpdateScriptFile() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getUpdateScriptInline() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getUpdateScriptLang() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getUpdateScriptParams() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getUpdateScriptParamsJson() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getUpdateScriptStored() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
getUser() - Method in class org.elasticsearch.hadoop.mr.security.HadoopRealUserProvider
 
getUser() - Method in class org.elasticsearch.hadoop.mr.security.HadoopUserProvider
 
getUser() - Method in class org.elasticsearch.hadoop.security.JdkUserProvider
 
getUser() - Method in class org.elasticsearch.hadoop.security.UserProvider
 
getUserName() - Method in class org.elasticsearch.hadoop.mr.security.HadoopUser
 
getUserName() - Method in class org.elasticsearch.hadoop.security.JdkUser
 
getUserName() - Method in interface org.elasticsearch.hadoop.security.User
 
getUserSpecifiedCheckpointLocation(Settings) - Method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
The name of the user specified checkpoint location for the current Spark Streaming Query, if set
getUserSpecifiedCheckpointLocation(Settings) - Static method in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
The name of the user specified checkpoint location for the current Spark Streaming Query, if set
getValue() - Method in enum org.elasticsearch.hadoop.security.AuthenticationMethod
The configuration value that corresponds to this method
getValue(MetadataExtractor.Metadata) - Method in class org.elasticsearch.spark.serialization.ScalaMetadataExtractor
 

H

HadoopCfgUtils - Class in org.elasticsearch.hadoop.mr
Class which handles the various Hadoop properties, aware of the changes between YARN (Hadoop 2) and 1.
HadoopCfgUtils() - Constructor for class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
HadoopIOUtils - Class in org.elasticsearch.hadoop.mr
 
HadoopIOUtils() - Constructor for class org.elasticsearch.hadoop.mr.HadoopIOUtils
 
HadoopRealUserProvider - Class in org.elasticsearch.hadoop.mr.security
When queried for a user object, this provider will obtain the currently logged in user, returning it if it is a regular user, or if it is a PROXY user, will retrieve the lowest level real user from it that has actual credentials.
HadoopRealUserProvider() - Constructor for class org.elasticsearch.hadoop.mr.security.HadoopRealUserProvider
 
HadoopSettings - Class in org.elasticsearch.hadoop.cfg
 
HadoopSettings(Configuration) - Constructor for class org.elasticsearch.hadoop.cfg.HadoopSettings
 
HadoopSettingsManager - Class in org.elasticsearch.hadoop.cfg
Factory for loading settings based on various configuration objects, such as Properties or Hadoop configuration.
HadoopSettingsManager() - Constructor for class org.elasticsearch.hadoop.cfg.HadoopSettingsManager
 
HadoopUser - Class in org.elasticsearch.hadoop.mr.security
Provides access to user operations from Hadoop's UserGroupInformation class.
HadoopUser(UserGroupInformation, Settings) - Constructor for class org.elasticsearch.hadoop.mr.security.HadoopUser
 
HadoopUserProvider - Class in org.elasticsearch.hadoop.mr.security
Retrieves the currently logged in Hadoop UGI.
HadoopUserProvider() - Constructor for class org.elasticsearch.hadoop.mr.security.HadoopUserProvider
Deprecated.
Use UserProvider.create(Settings) instead, or if it is important that you explicitly create a HadoopUserProvider, then use HadoopUserProvider.create(Settings) instead
handleKind(Text) - Method in class org.elasticsearch.hadoop.mr.security.EsTokenIdentifier.Renewer
 
HandlerLoader<E extends ErrorHandler> - Interface in org.elasticsearch.hadoop.handler
Any object that can produce a list of error handlers of a given type.
HandlerResult - Enum in org.elasticsearch.hadoop.handler
Values that denote the result of an action taken by an ErrorHandler.
handleUnknown(Object, ObjectInspector, Generator) - Method in class org.elasticsearch.hadoop.hive.HiveValueWriter
 
handleUnknown(Writable, Generator) - Method in class org.elasticsearch.hadoop.mr.WritableValueWriter
 
handleUnknown(Object, ResourceSchema.ResourceFieldSchema, Generator) - Method in class org.elasticsearch.hadoop.pig.PigValueWriter
 
handleUnknown(Object, Generator) - Method in class org.elasticsearch.spark.sql.DataFrameValueWriter
 
hashCode() - Method in class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable
 
hashCode() - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
 
hashCode() - Method in class org.elasticsearch.hadoop.security.EsToken
 
hashCode() - Method in class org.elasticsearch.spark.rdd.EsPartition
 
hasMappingVersionType() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
hasNext() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
hasUpdateScript() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
hasUpdateScriptParams() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
hasUpdateScriptParamsJson() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
HiveBytesArrayWritable - Class in org.elasticsearch.hadoop.hive
Replacement of BytesWritable that allows direct access to the underlying byte array without copying.
HiveBytesArrayWritable() - Constructor for class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable
 
HiveBytesArrayWritable.Comparator - Class in org.elasticsearch.hadoop.hive
 
HiveBytesConverter - Class in org.elasticsearch.hadoop.hive
 
HiveBytesConverter() - Constructor for class org.elasticsearch.hadoop.hive.HiveBytesConverter
 
HiveFieldExtractor - Class in org.elasticsearch.hadoop.hive
 
HiveFieldExtractor() - Constructor for class org.elasticsearch.hadoop.hive.HiveFieldExtractor
 
HiveType - Class in org.elasticsearch.hadoop.hive
Wrapper class around a Hive type - the value and its associated schema.
HiveType(Object, ObjectInspector) - Constructor for class org.elasticsearch.hadoop.hive.HiveType
 
HiveValueReader - Class in org.elasticsearch.hadoop.hive
 
HiveValueReader() - Constructor for class org.elasticsearch.hadoop.hive.HiveValueReader
 
HiveValueWriter - Class in org.elasticsearch.hadoop.hive
Main value writer for hive.
HiveValueWriter() - Constructor for class org.elasticsearch.hadoop.hive.HiveValueWriter
 
HiveWritableValueWriter - Class in org.elasticsearch.hadoop.hive
Writer for the Hive specific Writable types (specifically from serde2.io package).
HiveWritableValueWriter() - Constructor for class org.elasticsearch.hadoop.hive.HiveWritableValueWriter
 
HiveWritableValueWriter(boolean) - Constructor for class org.elasticsearch.hadoop.hive.HiveWritableValueWriter
 

I

inArray() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
index() - Method in class org.elasticsearch.spark.rdd.EsPartition
 
init(Properties) - Method in interface org.elasticsearch.hadoop.handler.ErrorHandler
Called at the handler creation time to initialize any internal state or resources.
init(Properties) - Method in class org.elasticsearch.hadoop.handler.impl.AbortOnFailure
 
init(Properties) - Method in class org.elasticsearch.hadoop.handler.impl.DropAndLog
 
init(Properties) - Method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
init() - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsRecordWriter
 
initCredentials(Job) - Static method in class org.elasticsearch.hadoop.mr.EsMapReduceUtil
Given the settings contained within a job object, retrieve an authentication token from either the currently logged in user or from the Elasticsearch cluster and add it to the job's credential set.
initCredentials(JobConf) - Static method in class org.elasticsearch.hadoop.mr.EsMapReduceUtil
Given the settings contained within the job conf, retrieve an authentication token from either the currently logged in user or from the Elasticsearch cluster and add it to the job's credential set.
initialize(Configuration, Properties, Properties) - Method in class org.elasticsearch.hadoop.hive.EsSerDe
 
initialize(Configuration, Properties) - Method in class org.elasticsearch.hadoop.hive.EsSerDe
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
initialized - Variable in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsRecordWriter
 
initJob(JobState) - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
Prepare the driver side of the commit protocol.
initReader(Settings, Log) - Method in class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
initReader(Settings, Log) - Method in class org.elasticsearch.spark.rdd.JavaEsRDDIterator
 
initReader(Settings, Log) - Method in class org.elasticsearch.spark.rdd.ScalaEsRDDIterator
 
initReader(Settings, Log) - Method in class org.elasticsearch.spark.sql.ScalaEsRowRDDIterator
 
initTask(TaskState) - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
Initialize the executor side of the commit protocol.
insert(Dataset<Row>, boolean) - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
INTERNAL_ES_CLUSTER_NAME - Static variable in interface org.elasticsearch.hadoop.cfg.InternalConfigurationOptions
 
INTERNAL_ES_CLUSTER_UUID - Static variable in interface org.elasticsearch.hadoop.cfg.InternalConfigurationOptions
 
INTERNAL_ES_DISCOVERED_NODES - Static variable in interface org.elasticsearch.hadoop.cfg.InternalConfigurationOptions
 
INTERNAL_ES_EXCLUDE_SOURCE - Static variable in interface org.elasticsearch.hadoop.cfg.InternalConfigurationOptions
 
INTERNAL_ES_EXCLUDE_SOURCE_DEFAULT - Static variable in interface org.elasticsearch.hadoop.cfg.InternalConfigurationOptions
 
INTERNAL_ES_PINNED_NODE - Static variable in interface org.elasticsearch.hadoop.cfg.InternalConfigurationOptions
 
INTERNAL_ES_QUERY_FILTERS - Static variable in interface org.elasticsearch.hadoop.cfg.InternalConfigurationOptions
 
INTERNAL_ES_TARGET_FIELDS - Static variable in interface org.elasticsearch.hadoop.cfg.InternalConfigurationOptions
 
INTERNAL_ES_VERSION - Static variable in interface org.elasticsearch.hadoop.cfg.InternalConfigurationOptions
 
INTERNAL_TRANSPORT_POOLING_KEY - Static variable in interface org.elasticsearch.hadoop.cfg.InternalConfigurationOptions
 
InternalConfigurationOptions - Interface in org.elasticsearch.hadoop.cfg
Property names for internal framework use.
intValue(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
isCaseClass(Product) - Method in class org.elasticsearch.spark.serialization.ReflectionUtils$
 
isCaseClass(Product) - Static method in class org.elasticsearch.spark.serialization.ReflectionUtils
 
isDeletingExpiredLog() - Method in class org.elasticsearch.spark.sql.streaming.EsSinkMetadataLog
 
isEmpty() - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
isEmpty() - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
isEsKerberosEnabled() - Method in class org.elasticsearch.hadoop.security.UserProvider
 
isJavaBean(Object) - Method in class org.elasticsearch.spark.serialization.ReflectionUtils$
 
isJavaBean(Object) - Static method in class org.elasticsearch.spark.serialization.ReflectionUtils
 
isLocal(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
isManaged(Token<?>) - Method in class org.elasticsearch.hadoop.mr.security.EsTokenIdentifier.Renewer
 
isNullAt(int) - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
isOutputAsJson(Configuration) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat
 
isProxyUser() - Method in class org.elasticsearch.hadoop.mr.security.HadoopUser
 
isProxyUser() - Method in class org.elasticsearch.hadoop.security.JdkUser
 
isProxyUser() - Method in interface org.elasticsearch.hadoop.security.User
 
isRequired() - Method in enum org.elasticsearch.hadoop.cfg.FieldPresenceValidation
 
isRequired() - Method in enum org.elasticsearch.storm.cfg.TupleFailureHandling
 
isShortWritable(Writable) - Static method in class org.elasticsearch.hadoop.mr.WritableCompatUtil
 
isTickTuple(Tuple) - Static method in class org.elasticsearch.storm.TupleUtils
 
iterator() - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 

J

javaBeanAsMap(Object) - Method in class org.elasticsearch.spark.serialization.ReflectionUtils$
 
javaBeanAsMap(Object) - Static method in class org.elasticsearch.spark.serialization.ReflectionUtils
 
javaBeanCache() - Method in class org.elasticsearch.spark.serialization.ReflectionUtils$
 
javaBeanCache() - Static method in class org.elasticsearch.spark.serialization.ReflectionUtils
 
JavaEsRDD<T> - Class in org.elasticsearch.spark.rdd
 
JavaEsRDD(SparkContext, Map<String, String>) - Constructor for class org.elasticsearch.spark.rdd.JavaEsRDD
 
JavaEsRDD$ - Class in org.elasticsearch.spark.rdd
 
JavaEsRDD$() - Constructor for class org.elasticsearch.spark.rdd.JavaEsRDD$
 
JavaEsRDDIterator<T> - Class in org.elasticsearch.spark.rdd
 
JavaEsRDDIterator(TaskContext, PartitionDefinition) - Constructor for class org.elasticsearch.spark.rdd.JavaEsRDDIterator
 
JavaEsSpark - Class in org.elasticsearch.spark.rdd.api.java
 
JavaEsSpark() - Constructor for class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
JavaEsSpark$ - Class in org.elasticsearch.spark.rdd.api.java
 
JavaEsSpark$() - Constructor for class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
JavaEsSparkSQL - Class in org.elasticsearch.spark.sql.api.java
 
JavaEsSparkSQL() - Constructor for class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
JavaEsSparkSQL$ - Class in org.elasticsearch.spark.sql.api.java
 
JavaEsSparkSQL$() - Constructor for class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
JavaEsSparkStreaming - Class in org.elasticsearch.spark.streaming.api.java
 
JavaEsSparkStreaming() - Constructor for class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
JavaEsSparkStreaming$ - Class in org.elasticsearch.spark.streaming.api.java
 
JavaEsSparkStreaming$() - Constructor for class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
JdkUser - Class in org.elasticsearch.hadoop.security
 
JdkUser(Subject, Settings) - Constructor for class org.elasticsearch.hadoop.security.JdkUser
 
JdkUserProvider - Class in org.elasticsearch.hadoop.security
Operates by retrieving the currently set subject in a way that ES-Hadoop understands, or a blank subject if there isn't currently one available.
JdkUserProvider() - Constructor for class org.elasticsearch.hadoop.security.JdkUserProvider
 
jobId() - Method in class org.elasticsearch.spark.sql.streaming.JobState
 
JobState - Class in org.elasticsearch.spark.sql.streaming
 
JobState(String, long) - Constructor for class org.elasticsearch.spark.sql.streaming.JobState
 
JobState$ - Class in org.elasticsearch.spark.sql.streaming
 
JobState$() - Constructor for class org.elasticsearch.spark.sql.streaming.JobState$
 
JsonWritableEsInputRecordReader() - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat.JsonWritableEsInputRecordReader
 
JsonWritableEsInputRecordReader(InputSplit, Configuration, Reporter) - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat.JsonWritableEsInputRecordReader
 

K

KEY_NAME_PREFIX - Static variable in class org.elasticsearch.hadoop.mr.security.TokenUtil
 
keySet() - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
KeystoreWrapper - Class in org.elasticsearch.hadoop.security
 
KeystoreWrapper.KeystoreBuilder - Class in org.elasticsearch.hadoop.security
 
keytabLogin(String, String) - Static method in class org.elasticsearch.hadoop.security.LoginUtil
 
Keytool - Class in org.elasticsearch.hadoop.cli
 
KIND_NAME - Static variable in class org.elasticsearch.hadoop.mr.security.EsTokenIdentifier
 
ksExists() - Method in class org.elasticsearch.hadoop.cli.Keytool
 

L

lazySchema() - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
length() - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
LinkedMapWritable - Class in org.elasticsearch.hadoop.mr
Similar to MapWritable expect that it uses a LinkedHashMap underneath to preserve insertion order (and thus its structure).
LinkedMapWritable() - Constructor for class org.elasticsearch.hadoop.mr.LinkedMapWritable
Default constructor.
LinkedMapWritable(MapWritable) - Constructor for class org.elasticsearch.hadoop.mr.LinkedMapWritable
Copy constructor.
listEntries() - Method in class org.elasticsearch.hadoop.security.KeystoreWrapper
 
load(Object) - Method in class org.elasticsearch.hadoop.cfg.HadoopSettingsManager
 
load(String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
load(T) - Method in interface org.elasticsearch.hadoop.cfg.SettingsManager
 
load(SparkConf) - Method in class org.elasticsearch.spark.cfg.SparkSettingsManager
 
loadBuiltInHandler(AbstractHandlerLoader.NamedHandlers) - Method in class org.elasticsearch.hadoop.handler.impl.AbstractHandlerLoader
Builds the integration specific built-in handler for the job described by the handler name.
loadFrom(Object) - Static method in class org.elasticsearch.hadoop.cfg.HadoopSettingsManager
 
loadHandlers() - Method in interface org.elasticsearch.hadoop.handler.HandlerLoader
 
loadHandlers() - Method in class org.elasticsearch.hadoop.handler.impl.AbstractHandlerLoader
 
loadHandlers() - Method in class org.elasticsearch.hadoop.handler.impl.PreloadedHandlerLoader
 
loadResource(String) - Method in class org.elasticsearch.hadoop.cfg.CompositeSettings
 
loadResource(String) - Method in class org.elasticsearch.hadoop.cfg.FilteredSettings
 
loadResource(String) - Method in class org.elasticsearch.hadoop.cfg.HadoopSettings
 
loadResource(String) - Method in class org.elasticsearch.hadoop.cfg.PropertiesSettings
 
loadResource(String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
loadResource(String) - Method in class org.elasticsearch.spark.cfg.SparkSettings
 
loadResource(String) - Method in class org.elasticsearch.storm.cfg.StormSettings
 
loadStore(String) - Static method in class org.elasticsearch.hadoop.security.KeystoreWrapper
 
loadStore(InputStream) - Static method in class org.elasticsearch.hadoop.security.KeystoreWrapper
 
log() - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
logger() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDD
 
logger() - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
 
login(String, String) - Static method in class org.elasticsearch.hadoop.security.LoginUtil
 
LoginUtil - Class in org.elasticsearch.hadoop.security
 
LoginUtil() - Constructor for class org.elasticsearch.hadoop.security.LoginUtil
 
LogRenderer<I extends Exceptional> - Class in org.elasticsearch.hadoop.handler.impl
 
LogRenderer() - Constructor for class org.elasticsearch.hadoop.handler.impl.LogRenderer
 
longValue(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 

M

main(String[]) - Static method in class org.elasticsearch.hadoop.cli.Keytool
 
map() - Method in class org.elasticsearch.spark.serialization.ScalaMetadataExtractor$
 
map() - Static method in class org.elasticsearch.spark.serialization.ScalaMetadataExtractor
 
mapping() - Method in class org.elasticsearch.spark.sql.SchemaUtils.Schema
 
merge(Properties) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
merge(Map<String, String>) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
Metadata - Enum in org.elasticsearch.spark.rdd
 
metadataExtractor() - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
metadataField() - Method in interface org.elasticsearch.spark.sql.RowValueReader
 
metadataMap() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
metaExtractor() - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
MODULE$ - Static variable in class org.elasticsearch.spark.rdd.AbstractEsRDD$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.rdd.EsRDDWriter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.rdd.EsSpark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.rdd.JavaEsRDD$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.rdd.ScalaEsRDD$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.serialization.ReflectionUtils$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.serialization.ReflectionUtils.ReflectionLock$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.serialization.ScalaMetadataExtractor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.serialization.ScalaValueWriter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.DataFrameValueWriter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.ElasticsearchRelation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.EsSparkSQL$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.ScalaEsRowRDD$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.SchemaUtils$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.SchemaUtils.Schema$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.streaming.EsSinkMetadataLog$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.streaming.EsSinkStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.streaming.JobState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.streaming.StructuredStreamingVersionLock$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.streaming.TaskCommit$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.sql.streaming.TaskState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.elasticsearch.spark.streaming.EsSparkStreaming$
Static reference to the singleton instance of this Scala object.
MultiOutputFormat - Class in org.elasticsearch.hadoop.mr
 
MultiOutputFormat() - Constructor for class org.elasticsearch.hadoop.mr.MultiOutputFormat
 

N

needsTaskCommit(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOldAPIOutputCommitter
 
needsTaskCommit(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOutputCommitter
 
newStore() - Static method in class org.elasticsearch.hadoop.security.KeystoreWrapper
 
next(K, V) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
next() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
nextKeyValue() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
 
nextTuple() - Method in class org.elasticsearch.storm.EsSpout
 
NullMetadataLog<T> - Class in org.elasticsearch.spark.sql.streaming
A null object style metadata log that discards incoming data, and otherwise acts like an empty log.
NullMetadataLog() - Constructor for class org.elasticsearch.spark.sql.streaming.NullMetadataLog
 
nullValue() - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
nullValue() - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 

O

obtainAndCache(RestClient, User) - Static method in class org.elasticsearch.hadoop.mr.security.TokenUtil
Obtain an authentication token for the given user and add it to the user's credentials.
obtainCredentials(Configuration, SparkConf, Credentials) - Method in class org.elasticsearch.spark.deploy.yarn.security.EsServiceCredentialProvider
Obtains api key tokens from Elasticsearch and stashes them in the given credentials object
obtainToken(RestClient, User) - Static method in class org.elasticsearch.hadoop.mr.security.TokenUtil
Obtain and return an authentication token for the current user.
obtainTokenForJob(RestClient, User, Job) - Static method in class org.elasticsearch.hadoop.mr.security.TokenUtil
Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
obtainTokenForJob(RestClient, User, JobConf) - Static method in class org.elasticsearch.hadoop.mr.security.TokenUtil
Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
onError(I, C) - Method in interface org.elasticsearch.hadoop.handler.ErrorHandler
Called when an exception or failure occurs in a part of the connector.
onError(I, C) - Method in class org.elasticsearch.hadoop.handler.impl.AbortOnFailure
 
onError(I, C) - Method in class org.elasticsearch.hadoop.handler.impl.DropAndLog
 
onError(I, C) - Method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.ElasticsearchHandler
 
open(String, Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopIOUtils
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.elasticsearch.storm.EsSpout
 
openRead() - Method in class org.elasticsearch.hadoop.cli.Keytool
 
openWrite() - Method in class org.elasticsearch.hadoop.cli.Keytool
 
org.elasticsearch.hadoop - package org.elasticsearch.hadoop
Base package providing common exceptions used by the Elasticsearch Hadoop library.
org.elasticsearch.hadoop.cfg - package org.elasticsearch.hadoop.cfg
Configuration package that handles loading across different environments.
org.elasticsearch.hadoop.cli - package org.elasticsearch.hadoop.cli
 
org.elasticsearch.hadoop.handler - package org.elasticsearch.hadoop.handler
 
org.elasticsearch.hadoop.handler.impl - package org.elasticsearch.hadoop.handler.impl
 
org.elasticsearch.hadoop.handler.impl.elasticsearch - package org.elasticsearch.hadoop.handler.impl.elasticsearch
 
org.elasticsearch.hadoop.hive - package org.elasticsearch.hadoop.hive
Integration for Apache Hive.
org.elasticsearch.hadoop.mr - package org.elasticsearch.hadoop.mr
Package providing integration between Elasticsearch and Map/Reduce package ('org.apache.hadoop.mapred' and 'org.apache.hadoop.mapreduce').
org.elasticsearch.hadoop.mr.security - package org.elasticsearch.hadoop.mr.security
 
org.elasticsearch.hadoop.pig - package org.elasticsearch.hadoop.pig
Package providing integration between ElasticSearch and Apache Pig.
org.elasticsearch.hadoop.security - package org.elasticsearch.hadoop.security
 
org.elasticsearch.spark.cfg - package org.elasticsearch.spark.cfg
Configuration package, specific for Apache Spark.
org.elasticsearch.spark.deploy.yarn.security - package org.elasticsearch.spark.deploy.yarn.security
 
org.elasticsearch.spark.rdd - package org.elasticsearch.spark.rdd
 
org.elasticsearch.spark.rdd.api.java - package org.elasticsearch.spark.rdd.api.java
Java API for Elasticsearch Spark RDD.
org.elasticsearch.spark.serialization - package org.elasticsearch.spark.serialization
 
org.elasticsearch.spark.sql - package org.elasticsearch.spark.sql
 
org.elasticsearch.spark.sql.api.java - package org.elasticsearch.spark.sql.api.java
Java API for Elasticsearch Spark SQL.
org.elasticsearch.spark.sql.streaming - package org.elasticsearch.spark.sql.streaming
 
org.elasticsearch.spark.streaming - package org.elasticsearch.spark.streaming
 
org.elasticsearch.spark.streaming.api.java - package org.elasticsearch.spark.streaming.api.java
Java API for Elasticsearch Spark Streaming.
org.elasticsearch.storm - package org.elasticsearch.storm
 
org.elasticsearch.storm.cfg - package org.elasticsearch.storm.cfg
 
org.elasticsearch.storm.security - package org.elasticsearch.storm.security
 
org.elasticsearch.storm.serialization - package org.elasticsearch.storm.serialization
 

P

parameters() - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
params() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDD
 
params(Map<String, String>) - Method in class org.elasticsearch.spark.sql.DefaultSource
 
parseBinary(byte[]) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
parseBoolean(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
parseByte(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
parseDate(Long, boolean) - Method in class org.elasticsearch.hadoop.hive.HiveValueReader
 
parseDate(String, boolean) - Method in class org.elasticsearch.hadoop.hive.HiveValueReader
 
parseDate(Long, boolean) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
parseDate(String, boolean) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
parseDate(Long, boolean) - Method in class org.elasticsearch.hadoop.pig.PigValueReader
 
parseDate(String, boolean) - Method in class org.elasticsearch.hadoop.pig.PigValueReader
 
parseDate(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
parseDouble(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
parseFloat(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
parseInt(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
parseLong(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
parseShort(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
parseString(String) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
parseText(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
pass(String) - Method in interface org.elasticsearch.hadoop.handler.ErrorCollector
Signal that a failure could not be handled by this handler and pass the record on to the next handler.
PigBytesConverter - Class in org.elasticsearch.hadoop.pig
 
PigBytesConverter() - Constructor for class org.elasticsearch.hadoop.pig.PigBytesConverter
 
PigEsInputRecordReader() - Constructor for class org.elasticsearch.hadoop.pig.EsPigInputFormat.PigEsInputRecordReader
 
PigEsInputRecordReader(InputSplit, Configuration, Reporter) - Constructor for class org.elasticsearch.hadoop.pig.EsPigInputFormat.PigEsInputRecordReader
 
PigFieldExtractor - Class in org.elasticsearch.hadoop.pig
 
PigFieldExtractor() - Constructor for class org.elasticsearch.hadoop.pig.PigFieldExtractor
 
PigJsonEsInputRecordReader() - Constructor for class org.elasticsearch.hadoop.pig.EsPigInputFormat.PigJsonEsInputRecordReader
 
PigJsonEsInputRecordReader(InputSplit, Configuration, Reporter) - Constructor for class org.elasticsearch.hadoop.pig.EsPigInputFormat.PigJsonEsInputRecordReader
 
PigTuple - Class in org.elasticsearch.hadoop.pig
Wrapper class around a Pig tuple - the value and its associated schema.
PigTuple(ResourceSchema) - Constructor for class org.elasticsearch.hadoop.pig.PigTuple
 
PigValueReader - Class in org.elasticsearch.hadoop.pig
 
PigValueReader() - Constructor for class org.elasticsearch.hadoop.pig.PigValueReader
 
PigValueWriter - Class in org.elasticsearch.hadoop.pig
 
PigValueWriter() - Constructor for class org.elasticsearch.hadoop.pig.PigValueWriter
 
PigValueWriter(boolean) - Constructor for class org.elasticsearch.hadoop.pig.PigValueWriter
 
populate(Settings) - Static method in class org.elasticsearch.storm.security.EsClusterInfoSelector
 
populateCredentials(Map<String, String>, Map) - Method in class org.elasticsearch.storm.security.AutoElasticsearch
Deprecated.
This is available for any storm cluster that operates against the older method of obtaining credentials
populateCredentials(Map<String, String>, Map<String, Object>, String) - Method in class org.elasticsearch.storm.security.AutoElasticsearch
 
populateCredentials(Map<String, String>) - Method in class org.elasticsearch.storm.security.AutoElasticsearch
 
populateSubject(Subject, Map<String, String>) - Method in class org.elasticsearch.storm.security.AutoElasticsearch
 
PreloadedHandlerLoader<E extends ErrorHandler> - Class in org.elasticsearch.hadoop.handler.impl
Returns the specified handlers as the loaded handlers.
PreloadedHandlerLoader(List<E>) - Constructor for class org.elasticsearch.hadoop.handler.impl.PreloadedHandlerLoader
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.elasticsearch.storm.EsBolt
 
prepare(Map) - Method in class org.elasticsearch.storm.security.AutoElasticsearch
 
prepareToRead(RecordReader, PigSplit) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
prepareToWrite(RecordWriter) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
previousHandlerMessages() - Method in interface org.elasticsearch.hadoop.handler.Exceptional
 
previousHandlerMessages() - Method in class org.elasticsearch.hadoop.handler.impl.BaseExceptional
 
printf(String, Object...) - Method in class org.elasticsearch.hadoop.cli.ConsolePrompt
 
printf(String, Object...) - Method in interface org.elasticsearch.hadoop.cli.Prompt
 
println() - Method in class org.elasticsearch.hadoop.cli.ConsolePrompt
 
println(String) - Method in class org.elasticsearch.hadoop.cli.ConsolePrompt
 
println() - Method in interface org.elasticsearch.hadoop.cli.Prompt
 
println(String) - Method in interface org.elasticsearch.hadoop.cli.Prompt
 
processBoolean(Boolean) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
processByte(Byte) - Method in class org.elasticsearch.hadoop.hive.HiveValueReader
 
processByte(Byte) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
processData(Iterator<T>) - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
processData(Iterator<Row>) - Method in class org.elasticsearch.spark.sql.EsDataFrameWriter
 
processData(Iterator<InternalRow>) - Method in class org.elasticsearch.spark.sql.streaming.EsStreamQueryWriter
 
processDouble(Double) - Method in class org.elasticsearch.hadoop.hive.HiveValueReader
 
processDouble(Double) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
processField(Settings, List<String>) - Method in class org.elasticsearch.hadoop.hive.HiveFieldExtractor
 
processFloat(Float) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
processInteger(Integer) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
processLong(Long) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
processShort(Short) - Method in class org.elasticsearch.hadoop.hive.HiveValueReader
 
processShort(Short) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
Prompt - Interface in org.elasticsearch.hadoop.cli
 
PropertiesSettings - Class in org.elasticsearch.hadoop.cfg
Properties-based settings - used for testing or local environments (including Cascading-local).
PropertiesSettings() - Constructor for class org.elasticsearch.hadoop.cfg.PropertiesSettings
 
PropertiesSettings(Properties) - Constructor for class org.elasticsearch.hadoop.cfg.PropertiesSettings
 
props - Variable in class org.elasticsearch.hadoop.cfg.PropertiesSettings
 
purge(long) - Method in class org.elasticsearch.spark.sql.streaming.NullMetadataLog
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
put(Writable, Writable) - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
putAll(Map<? extends Writable, ? extends Writable>) - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
putNext(Tuple) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 

R

reader() - Method in class org.elasticsearch.spark.rdd.AbstractEsRDDIterator
 
readFields(DataInput) - Method in class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable
 
readFields(DataInput) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputSplit
 
readFields(DataInput) - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
readFields(DataInput) - Method in class org.elasticsearch.hadoop.mr.WritableArrayWritable
 
readFrom(String) - Static method in class org.elasticsearch.hadoop.cfg.PropertiesSettings
 
readLine() - Method in class org.elasticsearch.hadoop.cli.ConsolePrompt
 
readLine(String, Object...) - Method in class org.elasticsearch.hadoop.cli.ConsolePrompt
 
readLine() - Method in interface org.elasticsearch.hadoop.cli.Prompt
 
readLine(String, Object...) - Method in interface org.elasticsearch.hadoop.cli.Prompt
 
readMetadata() - Method in interface org.elasticsearch.spark.sql.RowValueReader
 
readPassword(String, Object...) - Method in class org.elasticsearch.hadoop.cli.ConsolePrompt
 
readPassword(String, Object...) - Method in interface org.elasticsearch.hadoop.cli.Prompt
 
readValue(Parser, String, FieldType) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
readValue(Parser, String, FieldType) - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
records() - Method in class org.elasticsearch.spark.sql.streaming.EsSinkStatus
 
recordSeen() - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
Signal that a record has been processed in this transaction.
recordsWritten() - Method in class org.elasticsearch.spark.sql.streaming.EsCommitProtocol
 
ReflectionLock$() - Constructor for class org.elasticsearch.spark.serialization.ReflectionUtils.ReflectionLock$
 
ReflectionUtils - Class in org.elasticsearch.spark.serialization
 
ReflectionUtils() - Constructor for class org.elasticsearch.spark.serialization.ReflectionUtils
 
ReflectionUtils$ - Class in org.elasticsearch.spark.serialization
 
ReflectionUtils$() - Constructor for class org.elasticsearch.spark.serialization.ReflectionUtils$
 
ReflectionUtils.ReflectionLock$ - Class in org.elasticsearch.spark.serialization
 
relativeToAbsolutePath(String, Path) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
remove(Object) - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
removeSecureSetting(String) - Method in class org.elasticsearch.hadoop.security.KeystoreWrapper
 
renderEventMessage(E) - Method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.BaseEventConverter
Visible for testing
renderExceptionMessage(E) - Method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.BaseEventConverter
Visible for testing
renderExceptionType(E) - Method in class org.elasticsearch.hadoop.handler.impl.elasticsearch.BaseEventConverter
Visible for testing
renderLog(I) - Method in class org.elasticsearch.hadoop.handler.impl.LogRenderer
 
renew(Token<?>, Configuration) - Method in class org.elasticsearch.hadoop.mr.security.EsTokenIdentifier.Renewer
 
renew(Map<String, String>, Map) - Method in class org.elasticsearch.storm.security.AutoElasticsearch
Deprecated.
This is available for any storm cluster that operates against the older method of credential renewal
renew(Map<String, String>, Map<String, Object>, String) - Method in class org.elasticsearch.storm.security.AutoElasticsearch
 
Renewer() - Constructor for class org.elasticsearch.hadoop.mr.security.EsTokenIdentifier.Renewer
 
repository - Variable in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsRecordWriter
 
resource() - Method in class org.elasticsearch.spark.sql.streaming.EsSinkStatus
 
resource() - Method in class org.elasticsearch.spark.sql.streaming.TaskState
 
retry() - Method in interface org.elasticsearch.hadoop.handler.ErrorCollector
Retry an operation using the same data from the previous operation.
retry(T) - Method in interface org.elasticsearch.hadoop.handler.ErrorCollector
Retry an operation using the given retry data
richDate() - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
rootLevel() - Method in class org.elasticsearch.spark.sql.ScalaRowValueReader
 
rowColumns(String) - Method in interface org.elasticsearch.spark.sql.RowValueReader
 
rowColumnsMap() - Method in interface org.elasticsearch.spark.sql.RowValueReader
 
rowOrder() - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
RowValueReader - Interface in org.elasticsearch.spark.sql
 
run(String, boolean, boolean) - Method in class org.elasticsearch.hadoop.cli.Keytool
Run the program with the given arguments
run(TaskContext, Iterator<InternalRow>) - Method in class org.elasticsearch.spark.sql.streaming.EsStreamQueryWriter
 
runtimeMetadata() - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 

S

save() - Method in class org.elasticsearch.hadoop.cfg.Settings
 
saveJsonByteArrayToEs(JavaRDD<byte[]>, String) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveJsonByteArrayToEs(JavaRDD<byte[]>, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveJsonByteArrayToEs(JavaRDD<byte[]>, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveJsonByteArrayToEs(JavaRDD<byte[]>, String) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveJsonByteArrayToEs(JavaRDD<byte[]>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveJsonByteArrayToEs(JavaRDD<byte[]>, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveJsonByteArrayToEs(JavaDStream<byte[]>, String) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveJsonByteArrayToEs(JavaDStream<byte[]>, String, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveJsonByteArrayToEs(JavaDStream<byte[]>, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveJsonByteArrayToEs(JavaDStream<byte[]>, String) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveJsonByteArrayToEs(JavaDStream<byte[]>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveJsonByteArrayToEs(JavaDStream<byte[]>, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveJsonToEs(JavaRDD<String>, String) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveJsonToEs(JavaRDD<String>, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveJsonToEs(JavaRDD<String>, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveJsonToEs(JavaRDD<String>, String) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveJsonToEs(JavaRDD<String>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveJsonToEs(JavaRDD<String>, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveJsonToEs(RDD<?>, String) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
saveJsonToEs(RDD<?>, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
saveJsonToEs(RDD<?>, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
saveJsonToEs(RDD<?>, String) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
saveJsonToEs(RDD<?>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
saveJsonToEs(RDD<?>, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
saveJsonToEs(JavaDStream<String>, String) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveJsonToEs(JavaDStream<String>, String, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveJsonToEs(JavaDStream<String>, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveJsonToEs(JavaDStream<String>, String) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveJsonToEs(JavaDStream<String>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveJsonToEs(JavaDStream<String>, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveJsonToEs(DStream<?>, String) - Method in class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
saveJsonToEs(DStream<?>, String, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
saveJsonToEs(DStream<?>, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
saveJsonToEs(DStream<?>, String) - Static method in class org.elasticsearch.spark.streaming.EsSparkStreaming
 
saveJsonToEs(DStream<?>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.EsSparkStreaming
 
saveJsonToEs(DStream<?>, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.EsSparkStreaming
 
saveKeystore(OutputStream) - Method in class org.elasticsearch.hadoop.security.KeystoreWrapper
 
saveKeystore(String) - Method in class org.elasticsearch.hadoop.security.KeystoreWrapper
 
saveToEs(JavaRDD<?>, String) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveToEs(JavaRDD<?>, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveToEs(JavaRDD<?>, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveToEs(JavaRDD<?>, String) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveToEs(JavaRDD<?>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveToEs(JavaRDD<?>, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveToEs(RDD<?>, String) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
saveToEs(RDD<?>, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
saveToEs(RDD<?>, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
saveToEs(RDD<?>, String) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
saveToEs(RDD<?>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
saveToEs(RDD<?>, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
saveToEs(Dataset<T>, String) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
saveToEs(Dataset<T>, String, Map<String, String>) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
saveToEs(Dataset<T>, Map<String, String>) - Method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL$
 
saveToEs(Dataset<T>, String) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
saveToEs(Dataset<T>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
saveToEs(Dataset<T>, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.api.java.JavaEsSparkSQL
 
saveToEs(Dataset<?>, String) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
saveToEs(Dataset<?>, String, Map<String, String>) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
saveToEs(Dataset<?>, Map<String, String>) - Method in class org.elasticsearch.spark.sql.EsSparkSQL$
 
saveToEs(Dataset<?>, String) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
saveToEs(Dataset<?>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
saveToEs(Dataset<?>, Map<String, String>) - Static method in class org.elasticsearch.spark.sql.EsSparkSQL
 
saveToEs(JavaDStream<?>, String) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveToEs(JavaDStream<?>, String, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveToEs(JavaDStream<?>, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveToEs(JavaDStream<?>, String) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveToEs(JavaDStream<?>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveToEs(JavaDStream<?>, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveToEs(DStream<?>, String) - Method in class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
saveToEs(DStream<?>, String, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
saveToEs(DStream<?>, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
saveToEs(DStream<?>, String) - Static method in class org.elasticsearch.spark.streaming.EsSparkStreaming
 
saveToEs(DStream<?>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.EsSparkStreaming
 
saveToEs(DStream<?>, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.EsSparkStreaming
 
saveToEsWithMeta(JavaPairRDD<K, V>, String) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveToEsWithMeta(JavaPairRDD<K, V>, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveToEsWithMeta(JavaPairRDD<K, V>, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark$
 
saveToEsWithMeta(JavaPairRDD<K, V>, String) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveToEsWithMeta(JavaPairRDD<K, V>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveToEsWithMeta(JavaPairRDD<K, V>, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.api.java.JavaEsSpark
 
saveToEsWithMeta(RDD<Tuple2<K, V>>, String) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
saveToEsWithMeta(RDD<Tuple2<K, V>>, String, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
saveToEsWithMeta(RDD<Tuple2<K, V>>, Map<String, String>) - Method in class org.elasticsearch.spark.rdd.EsSpark$
 
saveToEsWithMeta(RDD<Tuple2<K, V>>, String) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
saveToEsWithMeta(RDD<Tuple2<K, V>>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
saveToEsWithMeta(RDD<Tuple2<K, V>>, Map<String, String>) - Static method in class org.elasticsearch.spark.rdd.EsSpark
 
saveToEsWithMeta(JavaPairDStream<K, V>, String) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveToEsWithMeta(JavaPairDStream<K, V>, String, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveToEsWithMeta(JavaPairDStream<K, V>, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming$
 
saveToEsWithMeta(JavaPairDStream<K, V>, String) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveToEsWithMeta(JavaPairDStream<K, V>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveToEsWithMeta(JavaPairDStream<K, V>, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.api.java.JavaEsSparkStreaming
 
saveToEsWithMeta(DStream<Tuple2<K, V>>, String) - Method in class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
saveToEsWithMeta(DStream<Tuple2<K, V>>, String, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
saveToEsWithMeta(DStream<Tuple2<K, V>>, Map<String, String>) - Method in class org.elasticsearch.spark.streaming.EsSparkStreaming$
 
saveToEsWithMeta(DStream<Tuple2<K, V>>, String) - Static method in class org.elasticsearch.spark.streaming.EsSparkStreaming
 
saveToEsWithMeta(DStream<Tuple2<K, V>>, String, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.EsSparkStreaming
 
saveToEsWithMeta(DStream<Tuple2<K, V>>, Map<String, String>) - Static method in class org.elasticsearch.spark.streaming.EsSparkStreaming
 
ScalaEsRDD<T> - Class in org.elasticsearch.spark.rdd
 
ScalaEsRDD(SparkContext, Map<String, String>) - Constructor for class org.elasticsearch.spark.rdd.ScalaEsRDD
 
ScalaEsRDD$ - Class in org.elasticsearch.spark.rdd
 
ScalaEsRDD$() - Constructor for class org.elasticsearch.spark.rdd.ScalaEsRDD$
 
ScalaEsRDDIterator<T> - Class in org.elasticsearch.spark.rdd
 
ScalaEsRDDIterator(TaskContext, PartitionDefinition) - Constructor for class org.elasticsearch.spark.rdd.ScalaEsRDDIterator
 
ScalaEsRow - Class in org.elasticsearch.spark.sql
 
ScalaEsRow(Seq<String>) - Constructor for class org.elasticsearch.spark.sql.ScalaEsRow
 
ScalaEsRow() - Constructor for class org.elasticsearch.spark.sql.ScalaEsRow
No-arg constructor for Kryo serialization.
ScalaEsRowRDD - Class in org.elasticsearch.spark.sql
 
ScalaEsRowRDD(SparkContext, Map<String, String>, SchemaUtils.Schema) - Constructor for class org.elasticsearch.spark.sql.ScalaEsRowRDD
 
ScalaEsRowRDD$ - Class in org.elasticsearch.spark.sql
 
ScalaEsRowRDD$() - Constructor for class org.elasticsearch.spark.sql.ScalaEsRowRDD$
 
ScalaEsRowRDDIterator - Class in org.elasticsearch.spark.sql
 
ScalaEsRowRDDIterator(TaskContext, PartitionDefinition, SchemaUtils.Schema) - Constructor for class org.elasticsearch.spark.sql.ScalaEsRowRDDIterator
 
ScalaMapFieldExtractor - Class in org.elasticsearch.spark.serialization
 
ScalaMapFieldExtractor() - Constructor for class org.elasticsearch.spark.serialization.ScalaMapFieldExtractor
 
ScalaMetadataExtractor - Class in org.elasticsearch.spark.serialization
 
ScalaMetadataExtractor() - Constructor for class org.elasticsearch.spark.serialization.ScalaMetadataExtractor
 
ScalaMetadataExtractor$ - Class in org.elasticsearch.spark.serialization
 
ScalaMetadataExtractor$() - Constructor for class org.elasticsearch.spark.serialization.ScalaMetadataExtractor$
 
ScalaRowValueReader - Class in org.elasticsearch.spark.sql
 
ScalaRowValueReader() - Constructor for class org.elasticsearch.spark.sql.ScalaRowValueReader
 
ScalaValueReader - Class in org.elasticsearch.spark.serialization
 
ScalaValueReader() - Constructor for class org.elasticsearch.spark.serialization.ScalaValueReader
 
ScalaValueWriter - Class in org.elasticsearch.spark.serialization
 
ScalaValueWriter(boolean) - Constructor for class org.elasticsearch.spark.serialization.ScalaValueWriter
 
ScalaValueWriter() - Constructor for class org.elasticsearch.spark.serialization.ScalaValueWriter
 
ScalaValueWriter$ - Class in org.elasticsearch.spark.serialization
 
ScalaValueWriter$() - Constructor for class org.elasticsearch.spark.serialization.ScalaValueWriter$
 
schema() - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
Schema(Mapping, StructType) - Constructor for class org.elasticsearch.spark.sql.SchemaUtils.Schema
 
Schema$() - Constructor for class org.elasticsearch.spark.sql.SchemaUtils.Schema$
 
SchemaUtils - Class in org.elasticsearch.spark.sql
 
SchemaUtils() - Constructor for class org.elasticsearch.spark.sql.SchemaUtils
 
SchemaUtils$ - Class in org.elasticsearch.spark.sql
 
SchemaUtils$() - Constructor for class org.elasticsearch.spark.sql.SchemaUtils$
 
SchemaUtils.Schema - Class in org.elasticsearch.spark.sql
 
SchemaUtils.Schema$ - Class in org.elasticsearch.spark.sql
 
SecureSettings - Class in org.elasticsearch.hadoop.security
Loads a keystore to retrieve secure settings, falling back to the settings object if the keystore is not configured or the property cannot be found.
SecureSettings(Settings) - Constructor for class org.elasticsearch.hadoop.security.SecureSettings
 
serialize(Object, ObjectInspector) - Method in class org.elasticsearch.hadoop.hive.EsSerDe
 
serializedSettings() - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
serializedSettings() - Method in class org.elasticsearch.spark.sql.EsDataFrameWriter
 
serviceName() - Method in class org.elasticsearch.spark.deploy.yarn.security.EsServiceCredentialProvider
Name of the service for logging purposes and for the purpose of determining if the service is disabled in the settings using the property spark.security.credentials.
setContent(BytesArray) - Method in class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable
 
setCurrentKey(Text, Object) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.AbstractWritableEsInputRecordReader
 
setCurrentKey(K, Object) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
Sets the current key.
setCurrentKey(String, Object) - Method in class org.elasticsearch.hadoop.pig.EsPigInputFormat.AbstractPigEsInputRecordReader
 
setCurrentValue(V, Object) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputRecordReader
Sets the current value.
setCurrentValue(Text, Object) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.JsonWritableEsInputRecordReader
 
setCurrentValue(Map<Writable, Writable>, Object) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.WritableEsInputRecordReader
 
setCurrentValue(Map, Object) - Method in class org.elasticsearch.hadoop.pig.EsPigInputFormat.PigEsInputRecordReader
 
setCurrentValue(String, Object) - Method in class org.elasticsearch.hadoop.pig.EsPigInputFormat.PigJsonEsInputRecordReader
 
setFileOutputFormatDir(Configuration, String) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
setFileSystem(Configuration, String) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
setGenericOptions(Configuration) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
setHosts(String) - Method in class org.elasticsearch.hadoop.cfg.Settings
Deprecated.
setInternalClusterInfo(ClusterInfo) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
setInternalVersion(EsMajorVersion) - Method in class org.elasticsearch.hadoop.cfg.Settings
Deprecated.
prefer to use Settings#setInternalClusterInfo
setJobTracker(Configuration, String) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
setLocation(String, Job) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
setMaxDocsPerPartition(int) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
setNodes(String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
setObject(Object) - Method in class org.elasticsearch.hadoop.hive.HiveType
 
setObjectInspector(ObjectInspector) - Method in class org.elasticsearch.hadoop.hive.HiveType
 
setOutputCommitterClass(Configuration, String) - Static method in class org.elasticsearch.hadoop.mr.HadoopCfgUtils
 
setPartitionFilter(Expression) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
setPassword(String) - Method in class org.elasticsearch.hadoop.security.KeystoreWrapper.KeystoreBuilder
 
setPort(int) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
setProperty(String, String) - Method in class org.elasticsearch.hadoop.cfg.CompositeSettings
 
setProperty(String, String) - Method in class org.elasticsearch.hadoop.cfg.FilteredSettings
 
setProperty(String, String) - Method in class org.elasticsearch.hadoop.cfg.HadoopSettings
 
setProperty(String, String) - Method in class org.elasticsearch.hadoop.cfg.PropertiesSettings
 
setProperty(String, String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
setProperty(String, String) - Method in class org.elasticsearch.spark.cfg.SparkSettings
 
setProperty(String, String) - Method in class org.elasticsearch.storm.cfg.StormSettings
 
setQuery(String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
setResourceRead(String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
setResourceWrite(String) - Method in class org.elasticsearch.hadoop.cfg.Settings
 
setRowInfo(Settings, StructType) - Method in class org.elasticsearch.spark.sql.SchemaUtils$
 
setRowInfo(Settings, StructType) - Static method in class org.elasticsearch.spark.sql.SchemaUtils
 
setSchema(ResourceSchema) - Method in class org.elasticsearch.hadoop.pig.PigTuple
 
setSecureSetting(String, String) - Method in class org.elasticsearch.hadoop.security.KeystoreWrapper
 
setSettings(Settings) - Method in class org.elasticsearch.hadoop.handler.impl.AbstractHandlerLoader
 
setSettings(Settings) - Method in class org.elasticsearch.hadoop.hive.HiveValueWriter
 
setSettings(Settings) - Method in class org.elasticsearch.hadoop.pig.PigValueWriter
 
setSettings(Settings) - Method in class org.elasticsearch.hadoop.security.UserProvider
 
setSettings(Settings) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
setSettings(Settings) - Method in class org.elasticsearch.spark.sql.DataFrameValueWriter
 
setSettings(Settings) - Method in interface org.elasticsearch.spark.sql.RowValueReader
 
setStoreFuncUDFContextSignature(String) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
setStoreLocation(String, Job) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
Settings - Class in org.elasticsearch.hadoop.cfg
Holder class containing the various configuration bits used by ElasticSearch Hadoop.
Settings() - Constructor for class org.elasticsearch.hadoop.cfg.Settings
 
settings - Variable in class org.elasticsearch.hadoop.security.UserProvider
 
settings() - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
SettingsManager<T> - Interface in org.elasticsearch.hadoop.cfg
 
setTuple(Tuple) - Method in class org.elasticsearch.hadoop.pig.PigTuple
 
setType(String) - Method in class org.elasticsearch.hadoop.security.KeystoreWrapper.KeystoreBuilder
 
setUDFContextSignature(String) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
setupJob(JobContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOldAPIOutputCommitter
 
setupJob(JobContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOldAPIOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsOutputCommitter
 
setValueClass(Class<Writable>) - Method in class org.elasticsearch.hadoop.mr.WritableArrayWritable
 
shortName() - Method in class org.elasticsearch.spark.sql.DefaultSource15
 
shortType() - Method in class org.elasticsearch.hadoop.hive.HiveValueReader
 
shortType() - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
shortValue(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
shutdown() - Method in class org.elasticsearch.storm.security.AutoElasticsearch
 
size() - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
sparkRowField() - Method in interface org.elasticsearch.spark.sql.RowValueReader
 
SparkSettings - Class in org.elasticsearch.spark.cfg
 
SparkSettings(SparkConf) - Constructor for class org.elasticsearch.spark.cfg.SparkSettings
 
SparkSettingsManager - Class in org.elasticsearch.spark.cfg
 
SparkSettingsManager() - Constructor for class org.elasticsearch.spark.cfg.SparkSettingsManager
 
SparkSQLCompatibilityLevel - Class in org.elasticsearch.spark.sql
For determining Spark Version Compatibility
SparkSQLCompatibilityLevel() - Constructor for class org.elasticsearch.spark.sql.SparkSQLCompatibilityLevel
 
SparkSqlStreamingConfigs - Class in org.elasticsearch.spark.sql.streaming
Configurations specifically used for Spark Structured Streaming
SparkSqlStreamingConfigs() - Constructor for class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs
 
SparkSqlStreamingConfigs$ - Class in org.elasticsearch.spark.sql.streaming
Configurations specifically used for Spark Structured Streaming
SparkSqlStreamingConfigs$() - Constructor for class org.elasticsearch.spark.sql.streaming.SparkSqlStreamingConfigs$
 
sqlContext() - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
statuses() - Method in class org.elasticsearch.spark.sql.streaming.TaskCommit
 
storeSchema(ResourceSchema, String, Job) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
storeStatistics(ResourceStatistics, String, Job) - Method in class org.elasticsearch.hadoop.pig.EsStorage
 
StormConfigurationOptions - Interface in org.elasticsearch.storm.cfg
 
StormSettings - Class in org.elasticsearch.storm.cfg
 
StormSettings(Map<?, ?>) - Constructor for class org.elasticsearch.storm.cfg.StormSettings
 
StormTupleBytesConverter - Class in org.elasticsearch.storm.serialization
 
StormTupleBytesConverter() - Constructor for class org.elasticsearch.storm.serialization.StormTupleBytesConverter
 
StormTupleFieldExtractor - Class in org.elasticsearch.storm.serialization
 
StormTupleFieldExtractor() - Constructor for class org.elasticsearch.storm.serialization.StormTupleFieldExtractor
 
StormValueWriter - Class in org.elasticsearch.storm.serialization
 
StormValueWriter() - Constructor for class org.elasticsearch.storm.serialization.StormValueWriter
 
StormValueWriter(boolean) - Constructor for class org.elasticsearch.storm.serialization.StormValueWriter
 
struct() - Method in class org.elasticsearch.spark.sql.SchemaUtils.Schema
 
StructuredStreamingVersionLock - Class in org.elasticsearch.spark.sql.streaming
Spark Structured Streaming just recently left "Experimental" mode in Spark 2.2.0.
StructuredStreamingVersionLock() - Constructor for class org.elasticsearch.spark.sql.streaming.StructuredStreamingVersionLock
 
StructuredStreamingVersionLock$ - Class in org.elasticsearch.spark.sql.streaming
Spark Structured Streaming just recently left "Experimental" mode in Spark 2.2.0.
StructuredStreamingVersionLock$() - Constructor for class org.elasticsearch.spark.sql.streaming.StructuredStreamingVersionLock$
 

T

TaskCommit - Class in org.elasticsearch.spark.sql.streaming
 
TaskCommit(Option<EsSinkStatus>) - Constructor for class org.elasticsearch.spark.sql.streaming.TaskCommit
 
TaskCommit$ - Class in org.elasticsearch.spark.sql.streaming
 
TaskCommit$() - Constructor for class org.elasticsearch.spark.sql.streaming.TaskCommit$
 
taskId() - Method in class org.elasticsearch.spark.sql.streaming.EsSinkStatus
 
taskId() - Method in class org.elasticsearch.spark.sql.streaming.TaskState
 
TaskState - Class in org.elasticsearch.spark.sql.streaming
 
TaskState(int, String) - Constructor for class org.elasticsearch.spark.sql.streaming.TaskState
 
TaskState$ - Class in org.elasticsearch.spark.sql.streaming
 
TaskState$() - Constructor for class org.elasticsearch.spark.sql.streaming.TaskState$
 
textValue(String, Parser) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
TokenUtil - Class in org.elasticsearch.hadoop.mr.security
Provides the main logic for obtaining Hadoop specific Tokens containing Elasticsearch authentication info, caching them in User objects (Subjects or Hadoop UGI), and adding them to jobs and job configurations.
TokenUtil() - Constructor for class org.elasticsearch.hadoop.mr.security.TokenUtil
 
toSeq() - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
toSparkEnum(MetadataExtractor.Metadata) - Method in class org.elasticsearch.spark.serialization.ScalaMetadataExtractor$
 
toSparkEnum(MetadataExtractor.Metadata) - Static method in class org.elasticsearch.spark.serialization.ScalaMetadataExtractor
 
toString() - Method in class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable
Generate the stream of bytes as hex pairs separated by ' '.
toString() - Method in class org.elasticsearch.hadoop.hive.HiveType
 
toString() - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputSplit
 
toString() - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
 
toString() - Method in class org.elasticsearch.hadoop.mr.security.HadoopUser
 
toString() - Method in class org.elasticsearch.hadoop.pig.PigTuple
 
toString() - Method in class org.elasticsearch.hadoop.security.EsToken
 
toString() - Method in class org.elasticsearch.hadoop.security.JdkUser
 
toString() - Static method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
toString() - Static method in class org.elasticsearch.spark.sql.streaming.EsSinkStatus
 
toString() - Static method in class org.elasticsearch.spark.sql.streaming.JobState
 
toString() - Static method in class org.elasticsearch.spark.sql.streaming.TaskCommit
 
toString() - Static method in class org.elasticsearch.spark.sql.streaming.TaskState
 
toString(Object) - Method in class org.elasticsearch.storm.serialization.StormTupleFieldExtractor
 
TupleFailureHandling - Enum in org.elasticsearch.storm.cfg
 
TupleUtils - Class in org.elasticsearch.storm
 
TupleUtils() - Constructor for class org.elasticsearch.storm.TupleUtils
 

U

unhandledFilters(Filter[]) - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
unwrap(Writable) - Static method in class org.elasticsearch.hadoop.mr.WritableCompatUtil
 
updateSubject(Subject, Map<String, String>) - Method in class org.elasticsearch.storm.security.AutoElasticsearch
 
User - Interface in org.elasticsearch.hadoop.security
Provides a platform independent way of accessing user information.
USER_KEYTAB - Static variable in class org.elasticsearch.storm.security.AutoElasticsearch
 
USER_PRINCIPAL - Static variable in class org.elasticsearch.storm.security.AutoElasticsearch
 
UserProvider - Class in org.elasticsearch.hadoop.security
Provides a platform independent way of retrieving the currently running user.
UserProvider() - Constructor for class org.elasticsearch.hadoop.security.UserProvider
 
userProvider() - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
userSchema() - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 

V

valueOf(String) - Static method in enum org.elasticsearch.hadoop.cfg.FieldPresenceValidation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.hadoop.handler.HandlerResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.hadoop.handler.impl.AbstractHandlerLoader.NamedHandlers
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.hadoop.mr.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.hadoop.security.AuthenticationMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.spark.rdd.Metadata
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.storm.cfg.TupleFailureHandling
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.elasticsearch.hadoop.cfg.FieldPresenceValidation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.hadoop.handler.HandlerResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.hadoop.handler.impl.AbstractHandlerLoader.NamedHandlers
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.hadoop.mr.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
values() - Static method in enum org.elasticsearch.hadoop.security.AuthenticationMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.spark.rdd.Metadata
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.elasticsearch.spark.sql.ScalaEsRow
 
values() - Static method in enum org.elasticsearch.storm.cfg.TupleFailureHandling
Returns an array containing the constants of this enum type, in the order they are declared.
valueWriter() - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
valueWriter() - Method in class org.elasticsearch.spark.sql.ElasticsearchRelation
 
valueWriter() - Method in class org.elasticsearch.spark.sql.EsDataFrameWriter
 
valueWriter() - Method in class org.elasticsearch.spark.sql.streaming.EsStreamQueryWriter
 
VERSION_NUMBER() - Method in class org.elasticsearch.spark.sql.streaming.EsSinkMetadataLog$
 
VERSION_NUMBER() - Static method in class org.elasticsearch.spark.sql.streaming.EsSinkMetadataLog
 
versionDescription() - Method in interface org.elasticsearch.spark.rdd.CompatibilityLevel
 
versionDescription() - Method in class org.elasticsearch.spark.sql.SparkSQLCompatibilityLevel
 
versionId() - Method in interface org.elasticsearch.spark.rdd.CompatibilityLevel
 
versionId() - Method in class org.elasticsearch.spark.sql.SparkSQLCompatibilityLevel
 

W

wrapArray(Object, int) - Method in class org.elasticsearch.hadoop.mr.WritableValueReader
 
wrapArray(Object, int) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
wrapString(String) - Method in class org.elasticsearch.spark.serialization.ScalaValueReader
 
WritableArrayWritable - Class in org.elasticsearch.hadoop.mr
 
WritableArrayWritable(Class<? extends Writable>, Writable[]) - Constructor for class org.elasticsearch.hadoop.mr.WritableArrayWritable
 
WritableArrayWritable(Class<? extends Writable>) - Constructor for class org.elasticsearch.hadoop.mr.WritableArrayWritable
 
WritableArrayWritable(String[]) - Constructor for class org.elasticsearch.hadoop.mr.WritableArrayWritable
 
WritableBytesConverter - Class in org.elasticsearch.hadoop.mr
 
WritableBytesConverter() - Constructor for class org.elasticsearch.hadoop.mr.WritableBytesConverter
 
WritableCompatUtil - Class in org.elasticsearch.hadoop.mr
Utility handling the difference in built-in Writable between Hadoop 1 and 2.
WritableCompatUtil() - Constructor for class org.elasticsearch.hadoop.mr.WritableCompatUtil
 
WritableEsInputRecordReader() - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat.WritableEsInputRecordReader
 
WritableEsInputRecordReader(InputSplit, Configuration, Reporter) - Constructor for class org.elasticsearch.hadoop.mr.EsInputFormat.WritableEsInputRecordReader
 
WritableValueReader - Class in org.elasticsearch.hadoop.mr
 
WritableValueReader() - Constructor for class org.elasticsearch.hadoop.mr.WritableValueReader
 
WritableValueWriter - Class in org.elasticsearch.hadoop.mr
 
WritableValueWriter() - Constructor for class org.elasticsearch.hadoop.mr.WritableValueWriter
 
WritableValueWriter(boolean) - Constructor for class org.elasticsearch.hadoop.mr.WritableValueWriter
 
write(DataOutput) - Method in class org.elasticsearch.hadoop.hive.HiveBytesArrayWritable
 
write(HiveType, Generator) - Method in class org.elasticsearch.hadoop.hive.HiveValueWriter
 
write(Writable, Generator) - Method in class org.elasticsearch.hadoop.hive.HiveWritableValueWriter
 
write(DataOutput) - Method in class org.elasticsearch.hadoop.mr.EsInputFormat.EsInputSplit
 
write(Object, Object) - Method in class org.elasticsearch.hadoop.mr.EsOutputFormat.EsRecordWriter
 
write(DataOutput) - Method in class org.elasticsearch.hadoop.mr.LinkedMapWritable
write(DataOutput) - Method in class org.elasticsearch.hadoop.mr.WritableArrayWritable
 
write(Writable, Generator) - Method in class org.elasticsearch.hadoop.mr.WritableValueWriter
 
write(PigTuple, Generator) - Method in class org.elasticsearch.hadoop.pig.PigValueWriter
 
write(TaskContext, Iterator<T>) - Method in class org.elasticsearch.spark.rdd.EsRDDWriter
 
write(Object, Generator) - Method in class org.elasticsearch.spark.serialization.ScalaValueWriter
 
write(Tuple2<Row, StructType>, Generator) - Method in class org.elasticsearch.spark.sql.DataFrameValueWriter
 
write(DataType, Object, Generator) - Method in class org.elasticsearch.spark.sql.DataFrameValueWriter
 
write(TaskContext, Iterator<InternalRow>) - Method in class org.elasticsearch.spark.sql.streaming.EsStreamQueryWriter
 
write(Tuple, Generator) - Method in class org.elasticsearch.storm.serialization.StormValueWriter
 
writeArray(ArrayType, Object, Generator) - Method in class org.elasticsearch.spark.sql.DataFrameValueWriter
 
writeMap(MapType, Object, Generator) - Method in class org.elasticsearch.spark.sql.DataFrameValueWriter
 
writeOut(DataOutput) - Method in class org.elasticsearch.hadoop.security.EsToken
 
writePrimitive(DataType, Object, Generator) - Method in class org.elasticsearch.spark.sql.DataFrameValueWriter
 
writeStruct(StructType, Object, Generator) - Method in class org.elasticsearch.spark.sql.DataFrameValueWriter
 
A B C D E F G H I J K L M N O P R S T U V W 
Skip navigation links
elasticsearch-hadoop