- AbstractAvroEventSerializer<T> - Class in org.apache.flume.serialization
-
This is a helper class provided to make it straightforward to serialize
Flume
events into Avro data.
- AbstractAvroEventSerializer() - Constructor for class org.apache.flume.serialization.AbstractAvroEventSerializer
-
- AbstractChannel - Class in org.apache.flume.channel
-
- AbstractChannel() - Constructor for class org.apache.flume.channel.AbstractChannel
-
- AbstractChannelSelector - Class in org.apache.flume.channel
-
- AbstractChannelSelector() - Constructor for class org.apache.flume.channel.AbstractChannelSelector
-
- AbstractConfigurationProvider - Class in org.apache.flume.node
-
- AbstractConfigurationProvider(String) - Constructor for class org.apache.flume.node.AbstractConfigurationProvider
-
- AbstractElasticSearchIndexRequestBuilderFactory - Class in org.apache.flume.sink.elasticsearch
-
- AbstractElasticSearchIndexRequestBuilderFactory(FastDateFormat) - Constructor for class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
-
Constructor for subclasses
- AbstractEventDrivenSource - Class in org.apache.flume.source
-
Base class which ensures sub-classes will inherit all the properties
of BasicSourceSemantics.
- AbstractEventDrivenSource() - Constructor for class org.apache.flume.source.AbstractEventDrivenSource
-
- AbstractHDFSWriter - Class in org.apache.flume.sink.hdfs
-
- AbstractHDFSWriter() - Constructor for class org.apache.flume.sink.hdfs.AbstractHDFSWriter
-
- AbstractPollableSource - Class in org.apache.flume.source
-
Base class which ensures sub-classes will inherit all the properties
of BasicSourceSemantics in addition to:
Ensuring when configure/start throw an exception process will not
be called
Ensure that process will not be called unless configure and start
have successfully been called
- AbstractPollableSource() - Constructor for class org.apache.flume.source.AbstractPollableSource
-
- AbstractRpcClient - Class in org.apache.flume.api
-
- AbstractRpcClient() - Constructor for class org.apache.flume.api.AbstractRpcClient
-
- AbstractRpcSink - Class in org.apache.flume.sink
-
This sink provides the basic RPC functionality for Flume.
- AbstractRpcSink() - Constructor for class org.apache.flume.sink.AbstractRpcSink
-
- AbstractSink - Class in org.apache.flume.sink
-
- AbstractSink() - Constructor for class org.apache.flume.sink.AbstractSink
-
- AbstractSinkProcessor - Class in org.apache.flume.sink
-
A convenience base class for sink processors.
- AbstractSinkProcessor() - Constructor for class org.apache.flume.sink.AbstractSinkProcessor
-
- AbstractSinkSelector - Class in org.apache.flume.sink
-
- AbstractSinkSelector() - Constructor for class org.apache.flume.sink.AbstractSinkSelector
-
- AbstractSource - Class in org.apache.flume.source
-
- AbstractSource() - Constructor for class org.apache.flume.source.AbstractSource
-
- AbstractZooKeeperConfigurationProvider - Class in org.apache.flume.node
-
ZooKeeper based configuration implementation provider.
- AbstractZooKeeperConfigurationProvider(String, String, String) - Constructor for class org.apache.flume.node.AbstractZooKeeperConfigurationProvider
-
- activateOptions() - Method in class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
-
Activate the options set using setHosts(), setSelector
and setMaxBackoff
- activateOptions() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
Activate the options set using setPort()
and setHostname()
- ACTIVE_KEY - Static variable in class org.apache.flume.channel.file.encryption.EncryptionConfiguration
-
Encryption key alias, default is null.
- ACTIVELOGS_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
- add(CounterGroup) - Method in class org.apache.flume.CounterGroup
-
- addActiveLogs(ProtosFactory.ActiveLog) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- addActiveLogs(int, ProtosFactory.ActiveLog) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- addActiveLogs(ProtosFactory.ActiveLog.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- addActiveLogs(int, ProtosFactory.ActiveLog.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- addActiveLogsBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- addActiveLogsBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- addAllActiveLogs(Iterable<? extends ProtosFactory.ActiveLog>) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- addAllHeaders(Iterable<? extends ProtosFactory.FlumeEventHeader>) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- addAndGet(String, Long) - Method in class org.apache.flume.CounterGroup
-
- addAndGet(String, long) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
-
Atomically adds the delta to the current value for this key
- addByteOffset(boolean) - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader.Builder
-
- addChannel(String, Channel) - Method in interface org.apache.flume.node.MaterializedConfiguration
-
- addChannel(String, Channel) - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
-
- addComplexField(XContentBuilder, String, XContentType, byte[]) - Static method in class org.apache.flume.sink.elasticsearch.ContentBuilderUtil
-
- addEvent(Event, IndexNameBuilder, String, long) - Method in interface org.apache.flume.sink.elasticsearch.client.ElasticSearchClient
-
Add new event to the bulk
- addEvent(Event, IndexNameBuilder, String, long) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchRestClient
-
- addEvent(Event, IndexNameBuilder, String, long) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
-
- addFieldsToBody(Set<String>, String, String, String, String, String) - Static method in class org.apache.flume.source.SyslogUtils
-
- addFormats(Map<String, String>) - Method in class org.apache.flume.source.SyslogUtils
-
- addHeaders(ProtosFactory.FlumeEventHeader) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- addHeaders(int, ProtosFactory.FlumeEventHeader) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- addHeaders(ProtosFactory.FlumeEventHeader.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- addHeaders(int, ProtosFactory.FlumeEventHeader.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- addHeadersBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- addHeadersBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- addSimpleField(XContentBuilder, String, byte[]) - Static method in class org.apache.flume.sink.elasticsearch.ContentBuilderUtil
-
- addSinkRunner(String, SinkRunner) - Method in interface org.apache.flume.node.MaterializedConfiguration
-
- addSinkRunner(String, SinkRunner) - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
-
- addSourceRunner(String, SourceRunner) - Method in interface org.apache.flume.node.MaterializedConfiguration
-
- addSourceRunner(String, SourceRunner) - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
-
- addToEventAcceptedCount(long) - Method in class org.apache.flume.instrumentation.SourceCounter
-
- addToEventDrainAttemptCount(long) - Method in class org.apache.flume.instrumentation.SinkCounter
-
- addToEventDrainSuccessCount(long) - Method in class org.apache.flume.instrumentation.SinkCounter
-
- addToEventPutSuccessCount(long) - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- addToEventReceivedCount(long) - Method in class org.apache.flume.instrumentation.SourceCounter
-
- addToEvents(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- addToEventTakeSuccessCount(long) - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- addToKafkaCommitTimer(long) - Method in class org.apache.flume.instrumentation.kafka.KafkaChannelCounter
-
- addToKafkaCommitTimer(long) - Method in class org.apache.flume.instrumentation.kafka.KafkaSourceCounter
-
- addToKafkaEventGetTimer(long) - Method in class org.apache.flume.instrumentation.kafka.KafkaChannelCounter
-
- addToKafkaEventGetTimer(long) - Method in class org.apache.flume.instrumentation.kafka.KafkaSourceCounter
-
- addToKafkaEventSendTimer(long) - Method in class org.apache.flume.instrumentation.kafka.KafkaChannelCounter
-
- addToKafkaEventSendTimer(long) - Method in class org.apache.flume.instrumentation.kafka.KafkaSinkCounter
-
- addToMessages(LogEntry) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- addToRollbackCounter(long) - Method in class org.apache.flume.instrumentation.kafka.KafkaChannelCounter
-
- AESCTRNoPaddingProvider - Class in org.apache.flume.channel.file.encryption
-
- AESCTRNoPaddingProvider() - Constructor for class org.apache.flume.channel.file.encryption.AESCTRNoPaddingProvider
-
- AESCTRNoPaddingProvider.DecryptorBuilder - Class in org.apache.flume.channel.file.encryption
-
- AESCTRNoPaddingProvider.EncryptorBuilder - Class in org.apache.flume.channel.file.encryption
-
- afterCreate() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
-
- afterCreate() - Method in class org.apache.flume.serialization.BodyTextEventSerializer
-
- afterCreate() - Method in interface org.apache.flume.serialization.EventSerializer
-
Hook to write a header after file is opened for the first time.
- afterCreate() - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer
-
- afterCreate() - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
-
- afterReopen() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
-
- afterReopen() - Method in class org.apache.flume.serialization.BodyTextEventSerializer
-
- afterReopen() - Method in interface org.apache.flume.serialization.EventSerializer
-
Hook to handle any framing needed when file is re-opened (for write).
Could have been named afterOpenForAppend()
.
- afterReopen() - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer
-
- afterReopen() - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
-
- ALIAS - Static variable in class org.apache.flume.sink.hive.HiveDelimitedTextSerializer
-
- ALIAS - Static variable in class org.apache.flume.sink.hive.HiveJsonSerializer
-
- allocate(int) - Static method in class org.apache.flume.tools.DirectMemoryUtils
-
- ALLOW_TOPIC_OVERRIDE_HEADER - Static variable in class org.apache.flume.sink.kafka.KafkaSinkConstants
-
- allowedFormats() - Method in class org.apache.flume.sink.kite.DatasetSink
-
Return the list of allowed formats.
- allowLogPrintConfig() - Static method in class org.apache.flume.conf.LogPrivacyUtil
-
Tells whether logging of potentially sensitive user data is allowed or not.
- allowLogRawData() - Static method in class org.apache.flume.conf.LogPrivacyUtil
-
Tells whether logging of configuration details - including secrets - is allowed or not.
- AlwaysRestartPolicy() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.SupervisorPolicy.AlwaysRestartPolicy
-
- annotateBaseName(Boolean) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
-
- annotateFileName(Boolean) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
-
- annotateFileName(boolean) - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader.Builder
-
- append(ThriftFlumeEvent, AsyncMethodCallback) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
-
- append(ThriftFlumeEvent, AsyncMethodCallback) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncIface
-
- append() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor.append
-
- append(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
-
- append(ThriftFlumeEvent) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Iface
-
- append() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor.append
-
- append(Event) - Method in class org.apache.flume.api.AbstractRpcClient
-
- append(Event) - Method in class org.apache.flume.api.FailoverRpcClient
-
Tries to append an event to the currently connected client.
- append(Event) - Method in class org.apache.flume.api.LoadBalancingRpcClient
-
- append(Event) - Method in class org.apache.flume.api.NettyAvroRpcClient
-
- append(Event) - Method in interface org.apache.flume.api.RpcClient
-
Send a single
Event
to the associated Flume source.
- append(Event) - Method in class org.apache.flume.api.ThriftRpcClient
-
- append(LoggingEvent) - Method in class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
-
- append(LoggingEvent) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
Append the LoggingEvent, to send to the first Flume hop.
- append(Event) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
-
- append(Event) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
-
- append(Event) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
-
- append(Event) - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
-
- append(AvroFlumeOGEvent) - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
-
- append(AvroFlumeEvent) - Method in class org.apache.flume.source.AvroSource
-
- append(ThriftFlumeEvent, AsyncMethodCallback) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient
-
- append(ThriftFlumeEvent, AsyncMethodCallback) - Method in interface org.apache.flume.thrift.ThriftSourceProtocol.AsyncIface
-
- append() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor.append
-
- append(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client
-
- append(ThriftFlumeEvent) - Method in interface org.apache.flume.thrift.ThriftSourceProtocol.Iface
-
- append() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.Processor.append
-
- append_args() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- append_args(ThriftFlumeEvent) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- append_args(ThriftFlumeEventServer.append_args) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
Performs a deep copy on other.
- append_args() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- append_args(ThriftFlumeEvent) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- append_args(ThriftSourceProtocol.append_args) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
Performs a deep copy on other.
- append_call(ThriftFlumeEvent, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.append_call
-
- append_call(ThriftFlumeEvent, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.append_call
-
- append_result() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- append_result(Status) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- append_result(ThriftSourceProtocol.append_result) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
Performs a deep copy on other.
- appendBatch(List<Event>) - Method in class org.apache.flume.api.AbstractRpcClient
-
- appendBatch(List<Event>) - Method in class org.apache.flume.api.FailoverRpcClient
-
Tries to append a list of events to the currently connected client.
- appendBatch(List<Event>) - Method in class org.apache.flume.api.LoadBalancingRpcClient
-
- appendBatch(List<Event>) - Method in class org.apache.flume.api.NettyAvroRpcClient
-
- appendBatch(List<Event>) - Method in interface org.apache.flume.api.RpcClient
-
Send a list of
events to the associated Flume source.
- appendBatch(List<Event>) - Method in class org.apache.flume.api.ThriftRpcClient
-
- appendBatch(List<AvroFlumeEvent>) - Method in class org.apache.flume.source.AvroSource
-
- appendBatch(List<ThriftFlumeEvent>, AsyncMethodCallback) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient
-
- appendBatch(List<ThriftFlumeEvent>, AsyncMethodCallback) - Method in interface org.apache.flume.thrift.ThriftSourceProtocol.AsyncIface
-
- appendBatch() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor.appendBatch
-
- appendBatch(List<ThriftFlumeEvent>) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client
-
- appendBatch(List<ThriftFlumeEvent>) - Method in interface org.apache.flume.thrift.ThriftSourceProtocol.Iface
-
- appendBatch() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.Processor.appendBatch
-
- appendBatch_args() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- appendBatch_args(List<ThriftFlumeEvent>) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- appendBatch_args(ThriftSourceProtocol.appendBatch_args) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
Performs a deep copy on other.
- appendBatch_call(List<ThriftFlumeEvent>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.appendBatch_call
-
- appendBatch_result() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- appendBatch_result(Status) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- appendBatch_result(ThriftSourceProtocol.appendBatch_result) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
Performs a deep copy on other.
- appendField(XContentBuilder, String, byte[]) - Static method in class org.apache.flume.sink.elasticsearch.ContentBuilderUtil
-
- Application - Class in org.apache.flume.node
-
- Application() - Constructor for class org.apache.flume.node.Application
-
- Application(List<LifecycleAware>) - Constructor for class org.apache.flume.node.Application
-
- AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
-
- AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.flume.source.scribe.Scribe.AsyncClient
-
- AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient
-
- AsyncHbaseEventSerializer - Interface in org.apache.flume.sink.hbase
-
Interface for an event serializer which serializes the headers and body
of an event to write them to hbase.
- AsyncHBaseSink - Class in org.apache.flume.sink.hbase
-
A simple sink which reads events from a channel and writes them to HBase.
- AsyncHBaseSink() - Constructor for class org.apache.flume.sink.hbase.AsyncHBaseSink
-
- AsyncHBaseSink(Configuration) - Constructor for class org.apache.flume.sink.hbase.AsyncHBaseSink
-
- AsyncProcessor(I) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor
-
- AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor
-
- AsyncProcessor(I) - Constructor for class org.apache.flume.source.scribe.Scribe.AsyncProcessor
-
- AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.flume.source.scribe.Scribe.AsyncProcessor
-
- AsyncProcessor(I) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor
-
- AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor
-
- AUTH_KEYTAB - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
- AUTH_PRINCIPAL - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
- AUTH_PROXY_USER - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Hadoop authentication settings
- AUTO_COMMIT_ENABLED - Static variable in class org.apache.flume.channel.kafka.KafkaChannelConfiguration
-
- AVAILABLE_PARSERS - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
- AVAILABLE_POLICIES - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
- AVG_EVENT_SIZE - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
-
Estimated average size of events expected to be in the channel
- AVRO_ENTITY_PARSER - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Built-in entity parsers
- AVRO_EVENT - Static variable in class org.apache.flume.sink.kafka.KafkaSinkConstants
-
- AVRO_EVENT - Static variable in class org.apache.flume.source.kafka.KafkaSourceConstants
-
- AVRO_SCHEMA_HEADER_HASH - Static variable in class org.apache.flume.serialization.AvroEventDeserializer
-
- AVRO_SCHEMA_HEADER_LITERAL - Static variable in class org.apache.flume.serialization.AvroEventDeserializer
-
- AVRO_SCHEMA_LITERAL_HEADER - Static variable in class org.apache.flume.sink.hdfs.AvroEventSerializer
-
- AVRO_SCHEMA_LITERAL_HEADER - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Headers where avro schema information is expected.
- AVRO_SCHEMA_URL_HEADER - Static variable in class org.apache.flume.sink.hdfs.AvroEventSerializer
-
- AVRO_SCHEMA_URL_HEADER - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
- AvroCLIClient - Class in org.apache.flume.client.avro
-
- AvroCLIClient() - Constructor for class org.apache.flume.client.avro.AvroCLIClient
-
- avroClient - Variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
-
- AvroEventDeserializer - Class in org.apache.flume.serialization
-
A deserializer that parses Avro container files, generating one Flume event
per record in the Avro file, and storing binary avro-encoded records in
the Flume event body.
- AvroEventDeserializer.AvroSchemaType - Enum in org.apache.flume.serialization
-
- AvroEventDeserializer.Builder - Class in org.apache.flume.serialization
-
- AvroEventSerializer - Class in org.apache.flume.sink.hdfs
-
This class serializes Flume
events into Avro data files.
- AvroEventSerializer.Builder - Class in org.apache.flume.sink.hdfs
-
- AvroEventSerializerConfigurationConstants - Class in org.apache.flume.serialization
-
- AvroEventSerializerConfigurationConstants() - Constructor for class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
-
- AvroLegacySource - Class in org.apache.flume.source.avroLegacy
-
A
Source
implementation that receives Avro events from Avro sink of
Flume OG
- AvroLegacySource() - Constructor for class org.apache.flume.source.avroLegacy.AvroLegacySource
-
- AvroParser - Class in org.apache.flume.sink.kite.parser
-
An
EntityParser
that parses Avro serialized bytes from an event.
- AvroParser.Builder - Class in org.apache.flume.sink.kite.parser
-
- AvroSink - Class in org.apache.flume.sink
-
A
Sink
implementation that can send events to an RPC server (such as
Flume's
AvroSource
).
- AvroSink() - Constructor for class org.apache.flume.sink.AvroSink
-
- AvroSource - Class in org.apache.flume.source
-
A
Source
implementation that receives Avro events from clients that
implement
AvroSourceProtocol
.
- AvroSource() - Constructor for class org.apache.flume.source.AvroSource
-
- CACHE_PATTERN_MATCHING - Static variable in class org.apache.flume.source.taildir.TaildirSourceConfigurationConstants
-
Whether to cache the list of files matching the specified file patterns till parent directory
is modified.
- cachePatternMatching(boolean) - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader.Builder
-
- CALL_TIMEOUT - Static variable in class org.apache.flume.sink.hive.Config
-
- CAPACITY - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
-
Maximum capacity of the channel.
- CAPACITY - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
-
file channel capacity overridden by Spillable Channel
- category - Variable in class org.apache.flume.source.scribe.LogEntry
-
- cf - Variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- CHANNEL - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Prefix for channel properties
- Channel - Interface in org.apache.flume
-
- channel - Variable in class org.apache.flume.conf.sink.SinkConfiguration
-
- CHANNEL_NAME_MAX_LENGTH - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
The maximum length of channel name.
- CHANNEL_PREFIX - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Prefix for passing configuration parameters to the channel
- CHANNEL_TYPE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Channel type, choices are `memory' or `file'
- CHANNEL_TYPE_FILE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
File based channel which stores events in on local disk.
- CHANNEL_TYPE_MEMORY - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Memory channel which stores events in heap.
- CHANNEL_TYPE_SPILLABLEMEMORY - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Spillable Memory channel which stores events in heap.
- ChannelConfiguration - Class in org.apache.flume.conf.channel
-
- ChannelConfiguration(String) - Constructor for class org.apache.flume.conf.channel.ChannelConfiguration
-
- ChannelConfiguration.ChannelConfigurationType - Enum in org.apache.flume.conf.channel
-
- channelCounter - Variable in class org.apache.flume.channel.SpillableMemoryChannel
-
- ChannelCounter - Class in org.apache.flume.instrumentation
-
- ChannelCounter(String) - Constructor for class org.apache.flume.instrumentation.ChannelCounter
-
- ChannelCounter(String, String[]) - Constructor for class org.apache.flume.instrumentation.ChannelCounter
-
- ChannelCounterMBean - Interface in org.apache.flume.instrumentation
-
This interface represents a channel counter mbean.
- ChannelException - Exception in org.apache.flume
-
A channel exception is raised whenever a channel operation fails.
- ChannelException(String) - Constructor for exception org.apache.flume.ChannelException
-
- ChannelException(Throwable) - Constructor for exception org.apache.flume.ChannelException
-
- ChannelException(String, Throwable) - Constructor for exception org.apache.flume.ChannelException
-
- ChannelFactory - Interface in org.apache.flume
-
- ChannelFullException - Exception in org.apache.flume
-
- ChannelFullException(String) - Constructor for exception org.apache.flume.ChannelFullException
-
- ChannelFullException(Throwable) - Constructor for exception org.apache.flume.ChannelFullException
-
- ChannelFullException(String, Throwable) - Constructor for exception org.apache.flume.ChannelFullException
-
- channelNames - Variable in class org.apache.flume.conf.channel.ChannelSelectorConfiguration
-
- ChannelProcessor - Class in org.apache.flume.channel
-
A channel processor exposes operations to put
Event
s into
Channel
s.
- ChannelProcessor(ChannelSelector) - Constructor for class org.apache.flume.channel.ChannelProcessor
-
- ChannelProcessorCounter - Class in org.apache.flume.instrumentation
-
- ChannelProcessorCounter(String) - Constructor for class org.apache.flume.instrumentation.ChannelProcessorCounter
-
- channels - Variable in class org.apache.flume.conf.source.SourceConfiguration
-
- ChannelSelector - Interface in org.apache.flume
-
Allows the selection of a subset of channels from the given set based on
its implementation policy.
- ChannelSelectorConfiguration - Class in org.apache.flume.conf.channel
-
- ChannelSelectorConfiguration(String) - Constructor for class org.apache.flume.conf.channel.ChannelSelectorConfiguration
-
- ChannelSelectorConfiguration.ChannelSelectorConfigurationType - Enum in org.apache.flume.conf.channel
-
- ChannelSelectorFactory - Class in org.apache.flume.channel
-
- ChannelSelectorFactory() - Constructor for class org.apache.flume.channel.ChannelSelectorFactory
-
- ChannelSelectorType - Enum in org.apache.flume.conf.channel
-
Enumeration of built in channel selector types available in the system.
- ChannelType - Enum in org.apache.flume.conf.channel
-
Enumeration of built in channel types available in the system.
- ChannelUtils - Class in org.apache.flume.channel
-
A collection of utilities for interacting with
Channel
objects.
- charset - Static variable in interface org.apache.flume.sink.elasticsearch.ElasticSearchEventSerializer
-
- CHARSET - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
-
Charset for reading input
- CHARSET_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
What charset to use when serializing into HBase's byte arrays
- CHARSET_DEFAULT - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- CHARSET_DFLT - Static variable in class org.apache.flume.serialization.LineDeserializer
-
- CHECKPOINT_DIR - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
-
Directory Checkpoints will be written in
- CHECKPOINT_INTERVAL - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
-
Interval at which checkpoints should be taken.
- CHECKPOINTPOSITION_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- CheckpointRebuilder - Class in org.apache.flume.channel.file
-
- CheckpointRebuilder(List<File>, FlumeEventQueue, boolean) - Constructor for class org.apache.flume.channel.file.CheckpointRebuilder
-
- CHECKPOINTWRITEORDERID_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- checkResultsAgainstSkew(PartitionTestScenario, Map<Integer, List<Event>>, Map<Integer, List<byte[]>>, int, int) - Static method in class org.apache.flume.shared.kafka.test.KafkaPartitionTestUtil
-
This method checks the retrieved messages (passed as resultsMap) against the expected
results (passed as partitionMap).
- CHECKSUM_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
- CHKPT_ONCLOSE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
-
- chooseFieldsToKeep(String) - Static method in class org.apache.flume.source.SyslogUtils
-
- CIPHER_PROVIDER - Static variable in class org.apache.flume.channel.file.encryption.EncryptionConfiguration
-
Encryption cipher provider, default is null.
- CipherProvider - Class in org.apache.flume.channel.file.encryption
-
- CipherProvider() - Constructor for class org.apache.flume.channel.file.encryption.CipherProvider
-
- CipherProvider.Decryptor - Class in org.apache.flume.channel.file.encryption
-
- CipherProvider.Decryptor.Builder<T extends CipherProvider.Decryptor> - Class in org.apache.flume.channel.file.encryption
-
Builder implementations MUST have a no-arg constructor
- CipherProvider.Encryptor - Class in org.apache.flume.channel.file.encryption
-
- CipherProvider.Encryptor.Builder<T extends CipherProvider.Encryptor> - Class in org.apache.flume.channel.file.encryption
-
Builder implementations MUST have a no-arg constructor
- CIPHERPROVIDER_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
- CipherProviderFactory - Class in org.apache.flume.channel.file.encryption
-
- CipherProviderFactory() - Constructor for class org.apache.flume.channel.file.encryption.CipherProviderFactory
-
- CipherProviderType - Enum in org.apache.flume.channel.file.encryption
-
- clean(ByteBuffer) - Static method in class org.apache.flume.tools.DirectMemoryUtils
-
- cleanUp() - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
-
Clean up any state.
- cleanUp() - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
-
- clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
-
- clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
-
- clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
- clear() - Method in class org.apache.flume.Context
-
Removes all of the mappings from this map.
- clear() - Method in class org.apache.flume.source.scribe.LogEntry
-
- clear() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- clear() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
- clear() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- clear() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- clear() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- clear() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- clear() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- clearActiveLogs() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- clearBackupCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional sfixed64 backupCheckpointPosition = 6;
- clearBackupCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional sfixed64 backupCheckpointWriteOrderID = 7;
- clearBody() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
required bytes body = 2;
- clearCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed64 checkpointPosition = 3;
- clearCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed64 checkpointWriteOrderID = 4;
- clearChecksum() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
optional sfixed64 checksum = 2;
- clearCipherProvider() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string cipherProvider = 1;
- clearCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
required sfixed32 count = 2;
- clearEncryption() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional .LogFileEncryption encryption = 5;
- clearEvent() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
required .FlumeEvent event = 1;
- clearFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
required sfixed32 fileID = 1;
- clearHeaders() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- clearKey() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
required string key = 1;
- clearKeyAlias() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string keyAlias = 2;
- clearLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
required sfixed32 logFileID = 1;
- clearLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed32 logFileID = 2;
- clearOffset() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
required sfixed32 offset = 2;
- clearParameters() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
optional bytes parameters = 3;
- clearQueueHead() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 queueHead = 4;
- clearQueueSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 queueSize = 3;
- clearTransactionID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed64 transactionID = 2;
- clearType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
required sfixed32 type = 1;
- clearType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed32 type = 1;
- clearValue() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
optional string value = 2;
- clearVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 version = 1;
- clearVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed32 version = 1;
- clearWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed64 writeOrderID = 2;
- clearWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed64 writeOrderID = 3;
- Client(TProtocol) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
-
- Client(TProtocol, TProtocol) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
-
- Client(TProtocol) - Constructor for class org.apache.flume.source.scribe.Scribe.Client
-
- Client(TProtocol, TProtocol) - Constructor for class org.apache.flume.source.scribe.Scribe.Client
-
- Client(TProtocol) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.Client
-
- Client(TProtocol, TProtocol) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.Client
-
- CLIENT_ID - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
-
- CLIENT_PREFIX - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
-
The client prefix to extract the configuration that will be passed to
elasticsearch client.
- CLIENT_TYPE - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
-
The client type used for sending bulks to ElasticSearch
- Clock - Interface in org.apache.flume
-
Facade for System.currentTimeMillis for Testing
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
-
- clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
- close(AsyncMethodCallback) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
-
- close(AsyncMethodCallback) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncIface
-
- close() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor.close
-
- close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
-
- close() - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Iface
-
- close() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor.close
-
- close() - Method in class org.apache.flume.api.AbstractRpcClient
-
- close() - Method in class org.apache.flume.api.FailoverRpcClient
-
Close the connection.
- close() - Method in class org.apache.flume.api.LoadBalancingRpcClient
-
- close() - Method in class org.apache.flume.api.NettyAvroRpcClient
-
- close() - Method in interface org.apache.flume.api.RpcClient
-
Immediately closes the client so that it may no longer be used.
- close() - Method in class org.apache.flume.api.ThriftRpcClient
-
- close() - Method in class org.apache.flume.channel.BasicTransactionSemantics
-
- close() - Method in class org.apache.flume.channel.ChannelProcessor
-
- close() - Method in class org.apache.flume.channel.file.LogFile.OperationRecordUpdater
-
- close() - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
-
- close() - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
-
- close() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
-
- close() - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
-
Deinitializes the channel provider.
- close() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
-
- close() - Method in interface org.apache.flume.client.avro.EventReader
-
Clean-up any state associated with this reader.
- close() - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader
-
- close() - Method in class org.apache.flume.client.avro.SimpleTextLineEventReader
-
- close() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
Closes underlying client.
- close() - Method in class org.apache.flume.interceptor.HostInterceptor
-
- close() - Method in interface org.apache.flume.interceptor.Interceptor
-
Perform any closing / shutdown needed by the Interceptor.
- close() - Method in class org.apache.flume.interceptor.InterceptorChain
-
- close() - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor
-
- close() - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor
-
- close() - Method in class org.apache.flume.interceptor.RemoveHeaderInterceptor
-
- close() - Method in class org.apache.flume.interceptor.SearchAndReplaceInterceptor
-
- close() - Method in class org.apache.flume.interceptor.StaticInterceptor
-
- close() - Method in class org.apache.flume.interceptor.TimestampInterceptor
-
- close() - Method in class org.apache.flume.serialization.AvroEventDeserializer
-
- close() - Method in class org.apache.flume.serialization.DurablePositionTracker
-
- close() - Method in interface org.apache.flume.serialization.EventDeserializer
-
- close() - Method in class org.apache.flume.serialization.LineDeserializer
-
- close() - Method in interface org.apache.flume.serialization.PositionTracker
-
- close() - Method in class org.apache.flume.serialization.ResettableFileInputStream
-
- close() - Method in class org.apache.flume.serialization.ResettableInputStream
-
- close() - Method in interface org.apache.flume.sink.elasticsearch.client.ElasticSearchClient
-
Close connection to elastic search in client
- close() - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchRestClient
-
- close() - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
-
- close() - Method in interface org.apache.flume.sink.hbase.HbaseEventSerializer
-
- close() - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- close() - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
-
- close() - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
-
- close() - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
-
- close() - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
-
- close() - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
-
- close() - Method in interface org.apache.flume.sink.kite.policy.FailurePolicy
-
Close this FailurePolicy and release any resources.
- close() - Method in class org.apache.flume.sink.kite.policy.RetryPolicy
-
- close() - Method in class org.apache.flume.sink.kite.policy.SavePolicy
-
- close() - Method in class org.apache.flume.sink.solr.morphline.BlobDeserializer
-
- close() - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor
-
- close() - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
-
- close() - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader
-
- close() - Method in class org.apache.flume.source.taildir.TailFile
-
- close() - Method in interface org.apache.flume.Transaction
-
Ends a transaction boundary for the current channel operation.
- close_args() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
-
- close_args(ThriftFlumeEventServer.close_args) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
-
Performs a deep copy on other.
- close_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
-
- close_result() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
-
- close_result(ThriftFlumeEventServer.close_result) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
-
Performs a deep copy on other.
- CLUSTER_NAME - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
-
Name of the ElasticSearch cluster to connect to
- COL_NAME_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
Comma separated list of column names to place matching groups in.
- collectorRunnable - Variable in class org.apache.flume.instrumentation.GangliaServer
-
- COLUMN_LOOKUP_QUERY - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- COLUMN_NAME_DEFAULT - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- com.cloudera.flume.handlers.thrift - package com.cloudera.flume.handlers.thrift
-
- commit() - Method in class org.apache.flume.channel.BasicTransactionSemantics
-
- commit() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
-
- commit() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
-
- commit() - Method in interface org.apache.flume.client.avro.ReliableEventReader
-
Indicate to the implementation that the previously-returned events have
been successfully processed and committed.
- commit() - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader
-
Commit the last lines which were read.
- commit() - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader
-
Commit the last lines which were read.
- commit() - Method in interface org.apache.flume.Transaction
-
Indicates that the transaction can be successfully committed.
- commitTransaction() - Method in interface org.apache.flume.sink.solr.morphline.MorphlineHandler
-
Sends any outstanding documents to Solr and waits for a positive
or negative ack (i.e.
- commitTransaction() - Method in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
-
- COMPACT_PROTOCOL - Static variable in class org.apache.flume.api.ThriftRpcClient
-
- COMPACT_PROTOCOL - Static variable in class org.apache.flume.source.ThriftSource
-
- compareTo(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- compareTo(ThriftFlumeEventServer.append_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- compareTo(ThriftFlumeEventServer.close_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
-
- compareTo(ThriftFlumeEventServer.close_result) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
-
- compareTo(LogRecord) - Method in class org.apache.flume.channel.file.LogRecord
-
- compareTo(LogEntry) - Method in class org.apache.flume.source.scribe.LogEntry
-
- compareTo(Scribe.Log_args) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- compareTo(Scribe.Log_result) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
- compareTo(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- compareTo(ThriftSourceProtocol.append_args) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- compareTo(ThriftSourceProtocol.append_result) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- compareTo(ThriftSourceProtocol.appendBatch_args) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- compareTo(ThriftSourceProtocol.appendBatch_result) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- completedSuffix(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
-
- ComponentConfiguration - Class in org.apache.flume.conf
-
Abstract implementation of the Component Configuration Manager.
- ComponentConfiguration(String) - Constructor for class org.apache.flume.conf.ComponentConfiguration
-
- ComponentConfiguration.ComponentType - Enum in org.apache.flume.conf
-
- ComponentConfigurationFactory - Class in org.apache.flume.conf
-
- ComponentConfigurationFactory() - Constructor for class org.apache.flume.conf.ComponentConfigurationFactory
-
- componentName - Variable in class org.apache.flume.conf.ComponentConfiguration
-
- COMPRESS_BACKUP_CHECKPOINT - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
-
- compressFile(File, File) - Static method in class org.apache.flume.channel.file.Serialization
-
Compress file using Snappy
- COMPRESSION_CODEC - Static variable in class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
-
Avro compression codec.
- CONF_HOSTS - Variable in class org.apache.flume.instrumentation.GangliaServer
-
- CONF_ISGANGLIA3 - Variable in class org.apache.flume.instrumentation.GangliaServer
-
- CONF_MONITOR_CLASS - Static variable in class org.apache.flume.node.Application
-
- CONF_MONITOR_PREFIX - Static variable in class org.apache.flume.node.Application
-
- CONF_POLL_FREQUENCY - Variable in class org.apache.flume.instrumentation.GangliaServer
-
- Config - Class in org.apache.flume.sink.hive
-
- Config() - Constructor for class org.apache.flume.sink.hive.Config
-
- CONFIG_ACKEVENT - Static variable in class org.apache.flume.source.NetcatSourceConfigurationConstants
-
Ack every event received with an "OK" back to the sender
- CONFIG_BACKOFF - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
- CONFIG_BACKOFF - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
-
- CONFIG_BATCH_SIZE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
Configuration key used to specify the batch size.
- CONFIG_BATCH_SIZE - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
-
Number of lines to read at a time
- CONFIG_BATCH_TIME_OUT - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
-
Amount of time to wait, if the buffer size was not reached, before
to data is pushed downstream: : default 3000 ms
- CONFIG_BATCHSIZE - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
Maximum number of events the sink should take from the channel per
transaction, if available.
- CONFIG_BATCHSIZE - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_BIND - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
-
- CONFIG_BIND - Static variable in class org.apache.flume.source.ThriftSource
-
Config param for the hostname to listen on.
- CONFIG_CHANNEL - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_CHANNELS - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_CHANNELS_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_CHARSET - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_CLIENT_TYPE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
Configuration key to specify the RpcClient type to be used.
- CONFIG_COALESCE_INCREMENTS - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
- CONFIG_COLUMN_FAMILY - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
The column family which the sink should use.
- CONFIG_COMPRESSION_LEVEL - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
- CONFIG_COMPRESSION_TYPE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
The following are const for the NettyAvro Client.
- CONFIG_CONFIG - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_CONNECT_TIMEOUT - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
Configuration key to specify connection timeout in milliseconds.
- CONFIG_CONNECTION_POOL_SIZE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
Maximum number of connections each Thrift Rpc client can open to a given
host.
- CONFIG_CREATE_FK - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_CREATE_INDEX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_CREATE_SCHEMA - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_DATABASE_TYPE - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_DATEFORMAT - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_DEFAULT_CHANNEL - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
-
- CONFIG_ENABLE_WAL - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
- CONFIG_ENTITY_PARSER - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Parser used to parse Flume Events into Kite entities.
- CONFIG_EVENTSIZE - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
Maximum allowable size of events.
- CONFIG_EXCLUDE_PROTOCOLS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
- CONFIG_FAILURE_POLICY - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Policy used to handle non-recoverable failures.
- CONFIG_FLUSHABLE_COMMIT_ON_BATCH - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Flag for committing the Flume transaction on each batch for Flushable
datasets.
- CONFIG_FORMAT_PREFIX - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_HANDLER - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
-
- CONFIG_HANDLER_PREFIX - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
-
- CONFIG_HEADER_NAME - Static variable in class org.apache.flume.interceptor.TimestampInterceptor.Constants
-
- CONFIG_HOST - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_HOST_SELECTOR - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
The selector type used by the LoadBalancingRpcClient.
- CONFIG_HOSTNAME - Static variable in class org.apache.flume.source.NetcatSourceConfigurationConstants
-
Hostname to bind to.
- CONFIG_HOSTS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
Hosts configuration key to specify a space delimited list of named
hosts.
- CONFIG_HOSTS_PREFIX - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
Hosts prefix to specify address of a particular named host.
- CONFIG_JDBC_DRIVER_CLASS - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_JDBC_PROPS_FILE - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_JDBC_SYSPROP_PREFIX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_KEEP_FIELDS - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_KEEP_FIELDS_HOSTNAME - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_KEEP_FIELDS_PRIORITY - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_KEEP_FIELDS_TIMESTAMP - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_KEEP_FIELDS_VERSION - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_KEYTAB - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
- CONFIG_KITE_BATCH_SIZE - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Number of records to process from the incoming channel per call to process.
- CONFIG_KITE_DATASET_NAME - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Name of the Kite Dataset to write into.
- CONFIG_KITE_DATASET_NAMESPACE - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Namespace of the Kite Dataset to write into.
- CONFIG_KITE_DATASET_URI - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
URI of the Kite Dataset
- CONFIG_KITE_ERROR_DATASET_URI - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
The URI to write non-recoverable Flume events to in the case of an error.
- CONFIG_KITE_REPO_URI - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
URI of the Kite DatasetRepository.
- CONFIG_KITE_ROLL_INTERVAL - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Maximum time to wait before finishing files.
- CONFIG_LOG_STDERR - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
-
Should stderr from the command be logged: default false
- CONFIG_MAX_ATTEMPTS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
Maximum attempts to be made by the FailoverRpcClient in case of
failures.
- CONFIG_MAX_BACKOFF - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
- CONFIG_MAX_CAPACITY - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_MAX_CONNECTIONS - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_MAX_CONSECUTIVE_FAILS - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
- CONFIG_MAX_LINE_LENGTH - Static variable in class org.apache.flume.source.NetcatSourceConfigurationConstants
-
Maximum line length per event.
- CONFIG_MULTIPLEX_HEADER_NAME - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
-
- CONFIG_NUMPROCESSORS - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
Number of processors used to calculate number of threads to spawn.
- CONFIG_OPTIONAL - Static variable in class org.apache.flume.channel.ReplicatingChannelSelector
-
Configuration to set a subset of the channels as optional.
- CONFIG_PASSWORD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_PORT - Static variable in class org.apache.flume.instrumentation.http.HTTPMetricsServer
-
- CONFIG_PORT - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
-
- CONFIG_PORT - Static variable in class org.apache.flume.source.NetcatSourceConfigurationConstants
-
Port to bind to.
- CONFIG_PORT - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_PORT - Static variable in class org.apache.flume.source.ThriftSource
-
Config param for the port to listen on.
- CONFIG_PORT_CHARSET_PREFIX - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_PORT_HEADER - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_PORTS - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
List of ports to listen to.
- CONFIG_PREFIX_MAPPING - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
-
- CONFIG_PREFIX_OPTIONAL - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
-
- CONFIG_PRESERVE - Static variable in class org.apache.flume.interceptor.TimestampInterceptor.Constants
-
- CONFIG_PRINCIPAL - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
- CONFIG_PROTOCOL - Static variable in class org.apache.flume.api.ThriftRpcClient
-
Config param for the thrift protocol to use.
- CONFIG_PROTOCOL - Static variable in class org.apache.flume.source.ThriftSource
-
Config param for the thrift protocol to use.
- CONFIG_READBUF_SIZE - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_REGEX - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_REPLACE - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_REQUEST_TIMEOUT - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
Configuration key to specify request timeout in milliseconds.
- CONFIG_RESTART - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
-
Should the exec'ed command restarted if it dies: : default false
- CONFIG_RESTART_THROTTLE - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
-
Amount of time to wait before attempting a restart: : default 10000 ms
- CONFIG_SCHEMA_TYPE_KEY - Static variable in class org.apache.flume.serialization.AvroEventDeserializer
-
- CONFIG_SEARCH - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
-
- CONFIG_SELECTOR - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
-
- CONFIG_SELECTOR_PREFIX - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
-
- CONFIG_SERIALIZER - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
The fully qualified class name of the serializer the sink should use.
- CONFIG_SERIALIZER_PREFIX - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
Configuration to pass to the serializer.
- CONFIG_SHELL - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
-
Optional shell/command processor used to run command
- CONFIG_SINK_PROCESSOR_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_SINKGROUPS - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_SINKGROUPS_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_SINKS - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_SINKS_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_SOURCE_CHANNELSELECTOR_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_SOURCE_ENCODING - Static variable in class org.apache.flume.source.NetcatSourceConfigurationConstants
-
Encoding for the netcat source
- CONFIG_SOURCES - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_SOURCES_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_SSL - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
Configuration constants for SSL support
- CONFIG_SYNCABLE_SYNC_ON_BATCH - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Flag for syncing the DatasetWriter on each batch for Syncable
datasets.
- CONFIG_TABLE - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
The Hbase table which the sink should write to.
- CONFIG_THREADS - Static variable in class org.apache.flume.source.ThriftSource
-
Config param for the maximum number of threads this source should use to
handle incoming data.
- CONFIG_TIMEOUT - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
- CONFIG_TRUST_ALL_CERTS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
- CONFIG_TRUSTSTORE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
- CONFIG_TRUSTSTORE_PASSWORD - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
- CONFIG_TRUSTSTORE_TYPE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
- CONFIG_TX_ISOLATION_LEVEL - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_TYPE - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
-
- CONFIG_URL - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- CONFIG_USERNAME - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
- configFromBytes(byte[]) - Method in class org.apache.flume.node.AbstractZooKeeperConfigurationProvider
-
- Configurable - Interface in org.apache.flume.conf
-
Any class marked as Configurable may have a context including its
sub-configuration passed to it, requesting it configure itself.
- ConfigurableComponent - Interface in org.apache.flume.conf
-
- Configurables - Class in org.apache.flume.conf
-
- Configurables() - Constructor for class org.apache.flume.conf.Configurables
-
- ConfigurationConstants - Class in org.apache.flume.channel.jdbc
-
Contains configuration keys used by the JDBC channel implementation.
- ConfigurationException - Exception in org.apache.flume.conf
-
- ConfigurationException(String) - Constructor for exception org.apache.flume.conf.ConfigurationException
-
- ConfigurationException(Throwable) - Constructor for exception org.apache.flume.conf.ConfigurationException
-
- ConfigurationException(String, Throwable) - Constructor for exception org.apache.flume.conf.ConfigurationException
-
- ConfigurationProvider - Interface in org.apache.flume.node
-
- configure(Map<String, String>) - Method in class org.apache.flume.agent.embedded.EmbeddedAgent
-
Configures the embedded agent.
- configure(Context) - Method in class org.apache.flume.agent.embedded.EmbeddedSource
-
- configure(Properties) - Method in class org.apache.flume.api.AbstractRpcClient
-
Configure the client using the given properties object.
- configure(Properties) - Method in class org.apache.flume.api.FailoverRpcClient
-
- configure(Properties) - Method in class org.apache.flume.api.LoadBalancingRpcClient
-
- configure(Properties) - Method in class org.apache.flume.api.NettyAvroRpcClient
-
Configure the actual client using the properties.
- configure(Properties) - Method in class org.apache.flume.api.SecureThriftRpcClient
-
- configure(Properties) - Method in class org.apache.flume.api.ThriftRpcClient
-
- configure(Context) - Method in class org.apache.flume.channel.AbstractChannel
-
- configure(Context) - Method in class org.apache.flume.channel.ChannelProcessor
-
The Context of the associated Source is passed.
- configure(Context) - Method in class org.apache.flume.channel.file.FileChannel
-
- configure(Context) - Method in class org.apache.flume.channel.jdbc.JdbcChannel
-
- configure(Context) - Method in class org.apache.flume.channel.kafka.KafkaChannel
-
- configure(Context) - Method in class org.apache.flume.channel.MemoryChannel
-
Read parameters from context
capacity = type long that defines the total number of events allowed at one time in the queue.
- configure(Context) - Method in class org.apache.flume.channel.MultiplexingChannelSelector
-
- configure(Context) - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
-
- configure(Context) - Method in class org.apache.flume.channel.ReplicatingChannelSelector
-
- configure(Context) - Method in class org.apache.flume.channel.SpillableMemoryChannel
-
Read parameters from context
memoryCapacity = total number of events allowed at one time in the memory queue.
- configure(Context) - Method in class org.apache.flume.conf.channel.ChannelConfiguration
-
- configure(Context) - Method in class org.apache.flume.conf.channel.ChannelSelectorConfiguration
-
- configure(Context) - Method in class org.apache.flume.conf.ComponentConfiguration
-
- configure(Context) - Method in interface org.apache.flume.conf.Configurable
-
Request the implementing class to (re)configure itself.
- configure(ComponentConfiguration) - Method in interface org.apache.flume.conf.ConfigurableComponent
-
- configure(Object, Context) - Static method in class org.apache.flume.conf.Configurables
-
Check that
target
implements
Configurable
and, if so, ask
it to configure itself using the supplied
context
.
- configure(Object, ComponentConfiguration) - Static method in class org.apache.flume.conf.Configurables
-
- configure(Context) - Method in class org.apache.flume.conf.sink.SinkConfiguration
-
- configure(Context) - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
-
- configure(Context) - Method in class org.apache.flume.conf.sink.SinkProcessorConfiguration
-
- configure(Context) - Method in class org.apache.flume.conf.source.SourceConfiguration
-
- configure(Context) - Method in class org.apache.flume.instrumentation.GangliaServer
-
- configure(Context) - Method in class org.apache.flume.instrumentation.http.HTTPMetricsServer
-
- configure(Context) - Method in class org.apache.flume.interceptor.HostInterceptor.Builder
-
- configure(Context) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor.Builder
-
- configure(Context) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorMillisSerializer
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorMillisSerializer
-
- configure(Context) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorPassThroughSerializer
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorPassThroughSerializer
-
- configure(Context) - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor.Builder
-
- configure(Context) - Method in class org.apache.flume.interceptor.RemoveHeaderInterceptor.Builder
-
- configure(Context) - Method in class org.apache.flume.interceptor.SearchAndReplaceInterceptor.Builder
-
- configure(Context) - Method in class org.apache.flume.interceptor.StaticInterceptor.Builder
-
- configure(Context) - Method in class org.apache.flume.interceptor.TimestampInterceptor.Builder
-
- configure(Context) - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
-
- configure(Context) - Method in class org.apache.flume.sink.AbstractRpcSink
-
- configure(Context) - Method in class org.apache.flume.sink.AbstractSinkSelector
-
- configure(Context) - Method in class org.apache.flume.sink.DefaultSinkProcessor
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.DefaultSinkProcessor
-
- configure(Context) - Method in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
-
- configure(Context) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchRestClient
-
- configure(Context) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
-
- configure(Context) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchDynamicSerializer
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchDynamicSerializer
-
- configure(Context) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchLogStashEventSerializer
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchLogStashEventSerializer
-
- configure(Context) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchSink
-
- configure(Context) - Method in class org.apache.flume.sink.elasticsearch.EventSerializerIndexRequestBuilderFactory
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.EventSerializerIndexRequestBuilderFactory
-
- configure(Context) - Method in class org.apache.flume.sink.elasticsearch.SimpleIndexNameBuilder
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.SimpleIndexNameBuilder
-
- configure(Context) - Method in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
-
- configure(Context) - Method in class org.apache.flume.sink.FailoverSinkProcessor
-
- configure(Context) - Method in class org.apache.flume.sink.hbase.AsyncHBaseSink
-
- configure(Context) - Method in class org.apache.flume.sink.hbase.HBaseSink
-
- configure(Context) - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- configure(Context) - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
-
- configure(Context) - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
-
- configure(Context) - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
-
- configure(Context) - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
-
- configure(Context) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
-
- configure(Context) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
-
- configure(Context) - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
-
- configure(Context) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
-
- configure(Context) - Method in class org.apache.flume.sink.hive.HiveDelimitedTextSerializer
-
- configure(Context) - Method in class org.apache.flume.sink.hive.HiveJsonSerializer
-
- configure(Context) - Method in class org.apache.flume.sink.hive.HiveSink
-
- configure(Context) - Method in class org.apache.flume.sink.http.HttpSink
-
- configure(Context) - Method in class org.apache.flume.sink.irc.IRCSink
-
- configure(Context) - Method in class org.apache.flume.sink.kafka.KafkaSink
-
We configure the sink and generate properties for the Kafka Producer
Kafka producer properties is generated as follows:
1.
- configure(Context) - Method in class org.apache.flume.sink.kite.DatasetSink
-
- configure(Context) - Method in class org.apache.flume.sink.LoadBalancingSinkProcessor
-
- configure(Context) - Method in class org.apache.flume.sink.LoggerSink
-
- configure(Context) - Method in class org.apache.flume.sink.NullSink
-
- configure(Context) - Method in class org.apache.flume.sink.RollingFileSink
-
- configure(Context) - Method in class org.apache.flume.sink.SinkGroup
-
- configure(ComponentConfiguration) - Method in class org.apache.flume.sink.SinkGroup
-
- configure(Context) - Method in class org.apache.flume.sink.solr.morphline.BlobHandler
-
- configure(Context) - Method in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
-
- configure(Context) - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor.Builder
-
- configure(Context) - Method in class org.apache.flume.sink.solr.morphline.MorphlineSink
-
- configure(Context) - Method in class org.apache.flume.sink.solr.morphline.MorphlineSolrSink
-
- configure(Context) - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor.Builder
-
- configure(Context) - Method in class org.apache.flume.source.AbstractPollableSource
-
- configure(Context) - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
-
- configure(Context) - Method in class org.apache.flume.source.AvroSource
-
- configure(Context) - Method in class org.apache.flume.source.BasicSourceSemantics
-
- configure(Context) - Method in class org.apache.flume.source.ExecSource
-
- configure(Context) - Method in class org.apache.flume.source.http.BLOBHandler
-
- configure(Context) - Method in class org.apache.flume.source.http.HTTPSource
-
- configure(Context) - Method in class org.apache.flume.source.http.JSONHandler
-
- configure(Context) - Method in class org.apache.flume.source.MultiportSyslogTCPSource
-
- configure(Context) - Method in class org.apache.flume.source.NetcatSource
-
- configure(Context) - Method in class org.apache.flume.source.NetcatUdpSource
-
- configure(Context) - Method in class org.apache.flume.source.scribe.ScribeSource
-
- configure(Context) - Method in class org.apache.flume.source.SpoolDirectorySource
-
- configure(Context) - Method in class org.apache.flume.source.SyslogTcpSource
-
Deprecated.
- configure(Context) - Method in class org.apache.flume.source.SyslogUDPSource
-
- configure(Context) - Method in class org.apache.flume.source.taildir.TaildirSource
-
- configure(Context) - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource
-
- configure(Context) - Method in class org.apache.flume.source.ThriftSource
-
- configure(Context) - Method in class org.apache.flume.source.twitter.TwitterSource
-
- configured - Variable in class org.apache.flume.conf.ComponentConfiguration
-
- CONNECTION_FACTORY - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
-
- CONNECTION_FACTORY_DEFAULT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
-
- connectTimeout - Variable in class org.apache.flume.api.AbstractRpcClient
-
- Constants - Class in org.apache.flume
-
- Constants() - Constructor for class org.apache.flume.interceptor.HostInterceptor.Constants
-
- Constants() - Constructor for class org.apache.flume.interceptor.RegexFilteringInterceptor.Constants
-
- Constants() - Constructor for class org.apache.flume.interceptor.StaticInterceptor.Constants
-
- Constants() - Constructor for class org.apache.flume.interceptor.TimestampInterceptor.Constants
-
- CONSUME_ORDER - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
-
- consumeOrder(SpoolDirectorySourceConfigurationConstants.ConsumeOrder) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
-
- CONSUMER_TIMEOUT - Static variable in class org.apache.flume.channel.kafka.KafkaChannelConfiguration
-
- containsKey(String) - Method in class org.apache.flume.Context
-
Returns true if this Context contains a mapping for key.
- containsTag(String) - Static method in class org.apache.flume.formatter.output.BucketPath
-
Deprecated.
- ContentBuilderUtil - Class in org.apache.flume.sink.elasticsearch
-
Utility methods for using ElasticSearch XContentBuilder
- Context - Class in org.apache.flume
-
The context is a key-value store used to pass configuration information
throughout the system.
- Context() - Constructor for class org.apache.flume.Context
-
- Context(Map<String, String>) - Constructor for class org.apache.flume.Context
-
- convert(Event) - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
-
Simple conversion routine used to convert an Event to a type of your
choosing.
- convert(Event) - Method in class org.apache.flume.serialization.FlumeEventAvroEventSerializer
-
A no-op for this simple, special-case implementation
- convert(Message) - Method in class org.apache.flume.source.jms.DefaultJMSMessageConverter
-
- convert(Message) - Method in interface org.apache.flume.source.jms.JMSMessageConverter
-
- CONVERTER - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
-
- CONVERTER_CHARSET - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
-
- CONVERTER_CHARSET_DEFAULT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
-
- CONVERTER_TYPE - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
-
- CONVERTER_TYPE_DEFAULT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
-
- copyFile(File, File) - Static method in class org.apache.flume.channel.file.Serialization
-
Copy a file using a 64K size buffer.
- CorruptEventException - Exception in org.apache.flume.channel.file
-
- CorruptEventException() - Constructor for exception org.apache.flume.channel.file.CorruptEventException
-
- CorruptEventException(String) - Constructor for exception org.apache.flume.channel.file.CorruptEventException
-
- CorruptEventException(String, Throwable) - Constructor for exception org.apache.flume.channel.file.CorruptEventException
-
- COUNT_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
- CounterGroup - Class in org.apache.flume
-
Used for counting events, collecting metrics, etc.
- CounterGroup() - Constructor for class org.apache.flume.CounterGroup
-
- create(List<Channel>, Map<String, String>) - Static method in class org.apache.flume.channel.ChannelSelectorFactory
-
- create(List<Channel>, ChannelSelectorConfiguration) - Static method in class org.apache.flume.channel.ChannelSelectorFactory
-
- create(String, String) - Method in class org.apache.flume.channel.DefaultChannelFactory
-
- create(String, String) - Method in interface org.apache.flume.ChannelFactory
-
- create(String, String, ComponentConfiguration.ComponentType) - Static method in class org.apache.flume.conf.ComponentConfigurationFactory
-
- create(String, String) - Method in class org.apache.flume.sink.DefaultSinkFactory
-
- create(String, String) - Method in interface org.apache.flume.SinkFactory
-
- create(String, String) - Method in class org.apache.flume.source.DefaultSourceFactory
-
- create(Properties) - Method in class org.apache.flume.source.jms.InitialContextFactory
-
- create(String, String) - Method in interface org.apache.flume.SourceFactory
-
- CREATE_DURABLE_SUBSCRIPTION - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
-
- createClient() - Method in class org.apache.flume.node.AbstractZooKeeperConfigurationProvider
-
- createGangliaMessage(String, String) - Method in class org.apache.flume.instrumentation.GangliaServer
-
- createGangliaMessage31(String, String) - Method in class org.apache.flume.instrumentation.GangliaServer
-
- createHostIterator() - Method in interface org.apache.flume.api.LoadBalancingRpcClient.HostSelector
-
- createIndexRequest(Client, String, String, Event) - Method in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
-
- createIndexRequest(Client, String, String, Event) - Method in interface org.apache.flume.sink.elasticsearch.ElasticSearchIndexRequestBuilderFactory
-
- createIterator() - Method in class org.apache.flume.util.OrderSelector
-
- createIterator() - Method in class org.apache.flume.util.RandomOrderSelector
-
- createIterator() - Method in class org.apache.flume.util.RoundRobinOrderSelector
-
- createRecordWriter(HiveEndPoint) - Method in class org.apache.flume.sink.hive.HiveDelimitedTextSerializer
-
- createRecordWriter(HiveEndPoint) - Method in interface org.apache.flume.sink.hive.HiveEventSerializer
-
- createRecordWriter(HiveEndPoint) - Method in class org.apache.flume.sink.hive.HiveJsonSerializer
-
- createSchemaObjects(boolean, boolean) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- createSchemaObjects(boolean, boolean) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
-
- createSchemaObjects(boolean, boolean) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
-
Creates the schema.
- createSinkIterator() - Method in interface org.apache.flume.sink.LoadBalancingSinkProcessor.SinkSelector
-
- createTransaction() - Method in class org.apache.flume.channel.BasicChannelSemantics
-
- createTransaction() - Method in class org.apache.flume.channel.file.FileChannel
-
- createTransaction() - Method in class org.apache.flume.channel.kafka.KafkaChannel
-
- createTransaction() - Method in class org.apache.flume.channel.MemoryChannel
-
- createTransaction() - Method in class org.apache.flume.channel.SpillableMemoryChannel
-
- CTX_PREFIX - Static variable in interface org.apache.flume.formatter.output.PathManager
-
- CTX_PREFIX - Static variable in interface org.apache.flume.serialization.EventSerializer
-
- currentFile - Variable in class org.apache.flume.formatter.output.DefaultPathManager
-
- currentTimeMillis() - Method in interface org.apache.flume.Clock
-
- currentTimeMillis() - Method in class org.apache.flume.SystemClock
-
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.Factory
-
- Factory() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
-
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.flume.source.scribe.Scribe.AsyncClient.Factory
-
- Factory() - Constructor for class org.apache.flume.source.scribe.Scribe.Client.Factory
-
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.Factory
-
- Factory() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.Client.Factory
-
- fail() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
-
- failIfConfigured() - Method in class org.apache.flume.conf.ComponentConfiguration
-
- FailoverRpcClient - Class in org.apache.flume.api
-
Avro/Netty implementation of
RpcClient
which supports failover.
- FailoverRpcClient() - Constructor for class org.apache.flume.api.FailoverRpcClient
-
- FailoverSinkProcessor - Class in org.apache.flume.sink
-
FailoverSinkProcessor maintains a prioritized list of sinks,
guarranteeing that so long as one is available events will be processed.
- FailoverSinkProcessor() - Constructor for class org.apache.flume.sink.FailoverSinkProcessor
-
- FailurePolicy - Interface in org.apache.flume.sink.kite.policy
-
A policy for dealing with non-recoverable event delivery failures.
- FailurePolicy.Builder - Interface in org.apache.flume.sink.kite.policy
-
Knows how to build FailurePolicy
s.
- FailurePolicyFactory - Class in org.apache.flume.sink.kite.policy
-
- FailurePolicyFactory() - Constructor for class org.apache.flume.sink.kite.policy.FailurePolicyFactory
-
- failures - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
-
- fastDateFormat - Variable in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
-
- fetchAndDeleteEvent(String, Connection) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- fetchAndDeleteEvent(String, Connection) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
-
- fetchAndDeleteEvent(String, Connection) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
-
Retrieves the next persistent event from the database.
- fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
-
- fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
-
- fieldForId(int) - Method in class org.apache.flume.source.scribe.LogEntry
-
- fieldForId(int) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- fieldForId(int) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
- fieldForId(int) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- fieldForId(int) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- fieldForId(int) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- fieldForId(int) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- fieldForId(int) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- fields - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- FILE_GROUPS - Static variable in class org.apache.flume.source.taildir.TaildirSourceConfigurationConstants
-
Mapping for tailing file groups.
- FILE_GROUPS_PREFIX - Static variable in class org.apache.flume.source.taildir.TaildirSourceConfigurationConstants
-
- FILE_LOCK - Static variable in class org.apache.flume.channel.file.Log
-
- FileChannel - Class in org.apache.flume.channel.file
-
A durable
Channel
implementation that uses the local file system for
its storage.
- FileChannel() - Constructor for class org.apache.flume.channel.file.FileChannel
-
- FileChannelConfiguration - Class in org.apache.flume.channel.file
-
- FileChannelConfiguration() - Constructor for class org.apache.flume.channel.file.FileChannelConfiguration
-
- FileChannelCounter - Class in org.apache.flume.channel.file.instrumentation
-
- FileChannelCounter(String) - Constructor for class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- FileChannelCounterMBean - Interface in org.apache.flume.channel.file.instrumentation
-
- FileChannelIntegrityTool - Class in org.apache.flume.tools
-
- FileChannelIntegrityTool() - Constructor for class org.apache.flume.tools.FileChannelIntegrityTool
-
- FILEID_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
- FILENAME_HEADER - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
-
Whether to include absolute path filename in a header.
- FILENAME_HEADER - Static variable in class org.apache.flume.source.taildir.TaildirSourceConfigurationConstants
-
Whether to include absolute path filename in a header.
- FILENAME_HEADER_KEY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
-
Header in which to put absolute path filename.
- FILENAME_HEADER_KEY - Static variable in class org.apache.flume.source.taildir.TaildirSourceConfigurationConstants
-
Header in which to put absolute path filename.
- fileNameHeader(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
-
- fileNameHeader(String) - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader.Builder
-
- filePaths(Map<String, String>) - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader.Builder
-
- FileWatcherRunnable(File, CounterGroup) - Constructor for class org.apache.flume.node.PollingPropertiesFileConfigurationProvider.FileWatcherRunnable
-
- findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.flume.source.scribe.LogEntry._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.flume.source.scribe.LogEntry._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.source.scribe.LogEntry._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByValue(int) - Static method in enum com.cloudera.flume.handlers.thrift.EventStatus
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum com.cloudera.flume.handlers.thrift.Priority
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.flume.source.scribe.ResultCode
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.flume.thrift.Status
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- firstSeen - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
-
- FLOOR_MINIMUM_REQUIRED_SPACE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
-
Minimum space floor is 1MB
- FlumeAuthenticationUtil - Class in org.apache.flume.auth
-
FlumeAuthentication utility class that provides methods to get an
Authenticator.
- FlumeAuthenticator - Interface in org.apache.flume.auth
-
FlumeAuthenticator extends on a PrivilegedExecutor providing capabilities to
proxy as a different user
- FlumeConfiguration - Class in org.apache.flume.conf
-
FlumeConfiguration is an in memory representation of the hierarchical
configuration namespace required by the ConfigurationProvider.
- FlumeConfiguration(Properties) - Constructor for class org.apache.flume.conf.FlumeConfiguration
-
- FlumeConfiguration(Map<String, String>) - Constructor for class org.apache.flume.conf.FlumeConfiguration
-
Creates a populated Flume Configuration object.
- FlumeConfiguration.AgentConfiguration - Class in org.apache.flume.conf
-
- FlumeConfiguration.ComponentNameAndConfigKey - Class in org.apache.flume.conf
-
- FlumeConfigurationError - Class in org.apache.flume.conf
-
- FlumeConfigurationError(String, String, FlumeConfigurationErrorType, FlumeConfigurationError.ErrorOrWarning) - Constructor for class org.apache.flume.conf.FlumeConfigurationError
-
Component which had an error, specific key in error(which can be null)
- FlumeConfigurationError.ErrorOrWarning - Enum in org.apache.flume.conf
-
- FlumeConfigurationErrorType - Enum in org.apache.flume.conf
-
- FlumeEventAvroEventSerializer - Class in org.apache.flume.serialization
-
- FlumeEventAvroEventSerializer.Builder - Class in org.apache.flume.serialization
-
- FlumeException - Exception in org.apache.flume
-
Base class of all flume exceptions.
- FlumeException(String) - Constructor for exception org.apache.flume.FlumeException
-
- FlumeException(String, Throwable) - Constructor for exception org.apache.flume.FlumeException
-
- FlumeException(Throwable) - Constructor for exception org.apache.flume.FlumeException
-
- FlumeTool - Interface in org.apache.flume.tools
-
- FlumeToolsMain - Class in org.apache.flume.tools
-
- FlumeToolType - Enum in org.apache.flume.tools
-
- flush() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
-
- flush() - Method in class org.apache.flume.serialization.BodyTextEventSerializer
-
- flush() - Method in interface org.apache.flume.serialization.EventSerializer
-
Hook to flush any internal write buffers to the underlying stream.
- flush() - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer
-
- flush() - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
-
- format(Event) - Method in interface org.apache.flume.formatter.output.EventFormatter
-
Deprecated.
- format(Event) - Method in class org.apache.flume.formatter.output.TextDelimitedOutputFormatter
-
Deprecated.
- forSource(Source) - Static method in class org.apache.flume.SourceRunner
-
Static factory method to instantiate a source runner implementation that
corresponds to the type of
Source
specified.
- front() - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
-
- FSYNC_INTERVAL - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
-
- FSYNC_PER_TXN - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
-
- GANGLIA_DOUBLE_TYPE - Static variable in class org.apache.flume.instrumentation.GangliaServer
-
- GangliaCollector() - Constructor for class org.apache.flume.instrumentation.GangliaServer.GangliaCollector
-
- GangliaServer - Class in org.apache.flume.instrumentation
-
A Ganglia server that polls JMX based at a configured frequency (defaults to
once every 60 seconds).
- GangliaServer() - Constructor for class org.apache.flume.instrumentation.GangliaServer
-
- GangliaServer.GangliaCollector - Class in org.apache.flume.instrumentation
-
Worker which polls JMX for all mbeans with
ObjectName
within the flume namespace:
org.apache.flume.
- generateSkewedMessageList(PartitionTestScenario, int, Map<Integer, List<Event>>, int, int) - Static method in class org.apache.flume.shared.kafka.test.KafkaPartitionTestUtil
-
This method is can be used to create a list of events for use in Kafka partition tests.
- generateUUID() - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
-
- get(String) - Method in class org.apache.flume.CounterGroup
-
- get(String) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
-
Retrieves the current value for this key
- get() - Method in class org.apache.flume.sink.elasticsearch.client.RoundRobinList
-
- get() - Method in class org.apache.flume.source.kafka.KafkaSource.Subscriber
-
- getActions() - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
-
Get the actions that should be written out to hbase as a result of this
event.
- getActions() - Method in interface org.apache.flume.sink.hbase.HbaseEventSerializer
-
Get the actions that should be written out to hbase as a result of this
event.
- getActions() - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- getActions() - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
-
- getActions() - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
-
- getActiveLogs(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogs(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogs(int) - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsCount() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsList() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsOrBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsOrBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsOrBuilder(int) - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsOrBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsOrBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
repeated .ActiveLog activeLogs = 5;
- getActiveLogsOrBuilderList() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
repeated .ActiveLog activeLogs = 5;
- getAgentName() - Method in class org.apache.flume.node.AbstractConfigurationProvider
-
- getAllChannels() - Method in class org.apache.flume.channel.AbstractChannelSelector
-
- getAllChannels() - Method in interface org.apache.flume.ChannelSelector
-
- getAllMBeans() - Static method in class org.apache.flume.instrumentation.util.JMXPollUtil
-
- getAppendAcceptedCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getAppendAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- getAppendAcceptedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
-
- getAppendBatchAcceptedCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getAppendBatchAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- getAppendBatchAcceptedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
-
- getAppendBatchReceivedCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getAppendBatchReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- getAppendBatchReceivedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
-
- getAppendReceivedCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getAppendReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- getAppendReceivedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
-
- getAsyncClient(TNonblockingTransport) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.Factory
-
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.flume.source.scribe.Scribe.AsyncClient.Factory
-
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.Factory
-
- getAuthenticator(String, String) - Static method in class org.apache.flume.auth.FlumeAuthenticationUtil
-
If principal and keytab are null, this method returns a SimpleAuthenticator
which executes without authentication.
- getBackOffSleepIncrement() - Method in interface org.apache.flume.PollableSource
-
- getBackOffSleepIncrement() - Method in class org.apache.flume.source.AbstractPollableSource
-
- getBackOffSleepIncrement() - Method in class org.apache.flume.source.taildir.TaildirSource
-
- getBackupCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional sfixed64 backupCheckpointPosition = 6;
- getBackupCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
optional sfixed64 backupCheckpointPosition = 6;
- getBackupCheckpointPosition() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
optional sfixed64 backupCheckpointPosition = 6;
- getBackupCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional sfixed64 backupCheckpointWriteOrderID = 7;
- getBackupCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
optional sfixed64 backupCheckpointWriteOrderID = 7;
- getBackupCheckpointWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
optional sfixed64 backupCheckpointWriteOrderID = 7;
- getBase() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
-
- getBaseDirectory() - Method in class org.apache.flume.formatter.output.DefaultPathManager
-
- getBaseDirectory() - Method in interface org.apache.flume.formatter.output.PathManager
-
- getBasePayload() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
-
- getBatchCompleteCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getBatchCompleteCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- getBatchCompleteCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getBatchEmptyCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getBatchEmptyCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- getBatchEmptyCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getBatchSize() - Method in class org.apache.flume.api.AbstractRpcClient
-
- getBatchSize() - Method in interface org.apache.flume.api.RpcClient
-
- getBatchSize() - Method in class org.apache.flume.api.ThriftRpcClient
-
- getBatchSize() - Method in class org.apache.flume.sink.kafka.KafkaSink
-
- getBatchUnderflowCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getBatchUnderflowCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- getBatchUnderflowCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- getBody() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
required bytes body = 2;
- getBody() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
required bytes body = 2;
- getBody() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
-
required bytes body = 2;
- getBody() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
-
- getBody() - Method in interface org.apache.flume.Event
-
Returns the raw byte array of the data contained in this event.
- getBody() - Method in class org.apache.flume.event.JSONEvent
-
- getBody() - Method in class org.apache.flume.event.SimpleEvent
-
- getBody() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- getBoolean(String, Boolean) - Method in class org.apache.flume.Context
-
Gets value mapped to key, returning defaultValue if unmapped.
- getBoolean(String) - Method in class org.apache.flume.Context
-
Gets value mapped to key, returning null if unmapped.
- getBranch() - Static method in class org.apache.flume.tools.VersionInfo
-
Get the branch on which this originated.
- getBuilderClass() - Method in enum org.apache.flume.channel.file.encryption.KeyProviderType
-
- getBuilderClass() - Method in enum org.apache.flume.formatter.output.PathManagerType
-
- getBuilderClass() - Method in enum org.apache.flume.interceptor.InterceptorType
-
- getBuilderClass() - Method in enum org.apache.flume.serialization.EventDeserializerType
-
- getBuilderClass() - Method in enum org.apache.flume.serialization.EventSerializerType
-
- getBuilderClass() - Method in enum org.apache.flume.sink.hdfs.SequenceFileSerializerType
-
- getBuildVersion() - Static method in class org.apache.flume.tools.VersionInfo
-
Returns the build version info which includes version,
revision, user, date and source checksum
- getByName(String) - Static method in enum org.apache.flume.channel.jdbc.DatabaseType
-
- getByName(String) - Static method in enum org.apache.flume.channel.jdbc.TransactionIsolation
-
- getByName(String) - Static method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
-
- getCategory() - Method in class org.apache.flume.source.scribe.LogEntry
-
- getChannel() - Method in class org.apache.flume.conf.sink.SinkConfiguration
-
- getChannel(String) - Method in class org.apache.flume.conf.sink.SinkConfiguration
-
- getChannel() - Method in class org.apache.flume.sink.AbstractSink
-
- getChannel() - Method in interface org.apache.flume.Sink
-
- getChannelCapacity() - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- getChannelCapacity() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
-
- getChannelCapacity() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getChannelClassName() - Method in enum org.apache.flume.conf.channel.ChannelType
-
- getChannelConfigMap() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getChannelConfigurationType() - Method in enum org.apache.flume.conf.channel.ChannelConfiguration.ChannelConfigurationType
-
- getChannelContext() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getChannelFillPercentage() - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- getChannelFillPercentage() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
-
- getChannelFillPercentage() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getChannelListFromNames(String, Map<String, Channel>) - Method in class org.apache.flume.channel.AbstractChannelSelector
-
Given a list of channel names as space delimited string,
returns list of channels.
- getChannelName() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
-
- getChannelNameMap() - Method in class org.apache.flume.channel.AbstractChannelSelector
-
- getChannelProcessor() - Method in class org.apache.flume.source.AbstractSource
-
- getChannelProcessor() - Method in class org.apache.flume.source.BasicSourceSemantics
-
- getChannelProcessor() - Method in interface org.apache.flume.Source
-
Returns the channel processor that will handle this source's events.
- getChannels() - Method in class org.apache.flume.conf.channel.ChannelSelectorConfiguration
-
- getChannels() - Method in class org.apache.flume.conf.source.SourceConfiguration
-
- getChannels() - Method in interface org.apache.flume.node.MaterializedConfiguration
-
- getChannels() - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
-
- getChannelSelectorClassName() - Method in enum org.apache.flume.conf.channel.ChannelSelectorType
-
- getChannelSelectorConfigurationType() - Method in enum org.apache.flume.conf.channel.ChannelSelectorConfiguration.ChannelSelectorConfigurationType
-
- getChannelSet() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getChannelSize(Connection) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- getChannelSize(Connection) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
-
- getChannelSize(Connection) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
-
Returns the current size of the channel using the connection specified that
must have an active transaction ongoing.
- getChannelSize() - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- getChannelSize() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
-
- getChannelSize() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getCheckpointBackupWriteErrorCount() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- getCheckpointBackupWriteErrorCount() - Method in interface org.apache.flume.channel.file.instrumentation.FileChannelCounterMBean
-
A count of the number of errors encountered while trying to write the backup checkpoints.
- getCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed64 checkpointPosition = 3;
- getCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
required sfixed64 checkpointPosition = 3;
- getCheckpointPosition() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
required sfixed64 checkpointPosition = 3;
- getCheckpointWriteErrorCount() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- getCheckpointWriteErrorCount() - Method in interface org.apache.flume.channel.file.instrumentation.FileChannelCounterMBean
-
A count of the number of errors encountered while trying to write the checkpoints.
- getCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed64 checkpointWriteOrderID = 4;
- getCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
required sfixed64 checkpointWriteOrderID = 4;
- getCheckpointWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
required sfixed64 checkpointWriteOrderID = 4;
- getChecksum() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
optional sfixed64 checksum = 2;
- getChecksum() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
optional sfixed64 checksum = 2;
- getChecksum() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.PutOrBuilder
-
optional sfixed64 checksum = 2;
- getCipherProvider() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string cipherProvider = 1;
- getCipherProvider() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
required string cipherProvider = 1;
- getCipherProvider() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
-
required string cipherProvider = 1;
- getCipherProviderBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string cipherProvider = 1;
- getCipherProviderBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
required string cipherProvider = 1;
- getCipherProviderBytes() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
-
required string cipherProvider = 1;
- getClass(String) - Method in class org.apache.flume.channel.DefaultChannelFactory
-
- getClass(String) - Method in interface org.apache.flume.ChannelFactory
-
- getClass(String) - Method in class org.apache.flume.sink.DefaultSinkFactory
-
- getClass(String) - Method in interface org.apache.flume.SinkFactory
-
- getClass(String) - Method in class org.apache.flume.source.DefaultSourceFactory
-
- getClass(String) - Method in interface org.apache.flume.SourceFactory
-
- getClassInstance() - Method in enum org.apache.flume.tools.FlumeToolType
-
- getClient(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
-
- getClient(TProtocol, TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
-
- getClient(String, String[], String, ElasticSearchEventSerializer, ElasticSearchIndexRequestBuilderFactory) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchClientFactory
-
- getClient(TProtocol) - Method in class org.apache.flume.source.scribe.Scribe.Client.Factory
-
- getClient(TProtocol, TProtocol) - Method in class org.apache.flume.source.scribe.Scribe.Client.Factory
-
- getClient(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client.Factory
-
- getClient(TProtocol, TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client.Factory
-
- getClientClassName() - Method in enum org.apache.flume.api.RpcClientFactory.ClientType
-
- getClock() - Static method in class org.apache.flume.formatter.output.BucketPath
-
- getClosed() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- getClosed() - Method in interface org.apache.flume.channel.file.instrumentation.FileChannelCounterMBean
-
The numeric representation (0/1) of the negated value of the open flag.
- getCode() - Method in enum org.apache.flume.channel.jdbc.TransactionIsolation
-
- getCodec() - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor
-
- getCodec() - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor
-
- getCommittedCount() - Method in class org.apache.flume.channel.file.Log
-
- getComponentName() - Method in class org.apache.flume.conf.ComponentConfiguration
-
- getComponentName() - Method in class org.apache.flume.conf.FlumeConfiguration.ComponentNameAndConfigKey
-
- getComponentName() - Method in class org.apache.flume.conf.FlumeConfigurationError
-
- getComponentType() - Method in enum org.apache.flume.conf.ComponentConfiguration.ComponentType
-
- getConfig() - Method in class org.apache.flume.sink.hbase.HBaseSink
-
- getConfigKey() - Method in class org.apache.flume.conf.FlumeConfiguration.ComponentNameAndConfigKey
-
- getConfiguration(String) - Method in enum org.apache.flume.conf.channel.ChannelConfiguration.ChannelConfigurationType
-
- getConfiguration(String) - Method in enum org.apache.flume.conf.channel.ChannelSelectorConfiguration.ChannelSelectorConfigurationType
-
- getConfiguration(String) - Method in enum org.apache.flume.conf.sink.SinkConfiguration.SinkConfigurationType
-
- getConfiguration(String) - Method in enum org.apache.flume.conf.sink.SinkProcessorConfiguration.SinkProcessorConfigurationType
-
- getConfiguration(String) - Method in enum org.apache.flume.conf.source.SourceConfiguration.SourceConfigurationType
-
- getConfiguration() - Method in class org.apache.flume.node.AbstractConfigurationProvider
-
- getConfiguration() - Method in interface org.apache.flume.node.ConfigurationProvider
-
- getConfigurationErrors() - Method in class org.apache.flume.conf.FlumeConfiguration
-
- getConfigurationFor(String) - Method in class org.apache.flume.conf.FlumeConfiguration
-
- getConnection() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
-
- getConnectionClosedCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getConnectionClosedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- getConnectionClosedCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getConnectionCreatedCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getConnectionCreatedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- getConnectionCreatedCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getConnectionFailedCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getConnectionFailedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- getConnectionFailedCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getConsumerProps() - Method in class org.apache.flume.channel.kafka.KafkaChannel
-
- getContentBuilder(Event) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchDynamicSerializer
-
- getContentBuilder(Event) - Method in interface org.apache.flume.sink.elasticsearch.ElasticSearchEventSerializer
-
Return an BytesStream
made up of the serialized flume event
- getContentBuilder(Event) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchLogStashEventSerializer
-
- getCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
required sfixed32 count = 2;
- getCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
required sfixed32 count = 2;
- getCount() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.ActiveLogOrBuilder
-
required sfixed32 count = 2;
- getCounter(String) - Method in class org.apache.flume.CounterGroup
-
- getCounter() - Method in class org.apache.flume.sink.hive.HiveSink
-
- getCounters() - Method in class org.apache.flume.CounterGroup
-
- getCurrentFile() - Method in class org.apache.flume.formatter.output.DefaultPathManager
-
- getCurrentFile() - Method in interface org.apache.flume.formatter.output.PathManager
-
- getDate() - Static method in class org.apache.flume.tools.VersionInfo
-
The date that Flume was compiled.
- getDecrypter(String, Key, byte[]) - Static method in class org.apache.flume.channel.file.encryption.CipherProviderFactory
-
- getDefaultInstance(String, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
-
Returns an instance of
RpcClient
connected to the specified
hostname
and
port
.
- getDefaultInstance(String, Integer, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
-
Returns an instance of
RpcClient
connected to the specified
hostname
and
port
with the specified
batchSize
.
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
-
- getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
- getDepth() - Method in class org.apache.flume.channel.file.FileChannel
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
- getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
-
- getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
- getDfs(Configuration, Path) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
-
- getDirectMemorySize() - Static method in class org.apache.flume.tools.DirectMemoryUtils
-
- getDirectory() - Method in class org.apache.flume.sink.RollingFileSink
-
- getEmptyArgsInstance() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor.append
-
- getEmptyArgsInstance() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor.close
-
- getEmptyArgsInstance() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor.append
-
- getEmptyArgsInstance() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor.close
-
- getEmptyArgsInstance() - Method in class org.apache.flume.source.scribe.Scribe.AsyncProcessor.Log
-
- getEmptyArgsInstance() - Method in class org.apache.flume.source.scribe.Scribe.Processor.Log
-
- getEmptyArgsInstance() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor.append
-
- getEmptyArgsInstance() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor.appendBatch
-
- getEmptyArgsInstance() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Processor.append
-
- getEmptyArgsInstance() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Processor.appendBatch
-
- getEncrypter(String, Key) - Static method in class org.apache.flume.channel.file.encryption.CipherProviderFactory
-
- getEncryption() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional .LogFileEncryption encryption = 5;
- getEncryption() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
optional .LogFileEncryption encryption = 5;
- getEncryption() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
optional .LogFileEncryption encryption = 5;
- getEncryptionBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional .LogFileEncryption encryption = 5;
- getEncryptionOrBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional .LogFileEncryption encryption = 5;
- getEncryptionOrBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
optional .LogFileEncryption encryption = 5;
- getEncryptionOrBuilder() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
optional .LogFileEncryption encryption = 5;
- getError() - Method in enum org.apache.flume.conf.FlumeConfigurationErrorType
-
- getErrorOrWarning() - Method in class org.apache.flume.conf.FlumeConfigurationError
-
- getErrors() - Method in class org.apache.flume.conf.ComponentConfiguration
-
- getErrorType() - Method in class org.apache.flume.conf.FlumeConfigurationError
-
- getEscapeMapping(String, Map<String, String>) - Static method in class org.apache.flume.formatter.output.BucketPath
-
Deprecated.
- getEscapeMapping(String, Map<String, String>, boolean, int, int) - Static method in class org.apache.flume.formatter.output.BucketPath
-
Deprecated.
- getEvent() - Method in class org.apache.flume.channel.file.LogRecord
-
- getEvent() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
required .FlumeEvent event = 1;
- getEvent() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
required .FlumeEvent event = 1;
- getEvent() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.PutOrBuilder
-
required .FlumeEvent event = 1;
- getEvent() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- getEventAcceptedCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getEventAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- getEventAcceptedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
-
- getEventBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
required .FlumeEvent event = 1;
- getEventDrainAttemptCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getEventDrainAttemptCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- getEventDrainAttemptCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getEventDrainSuccessCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getEventDrainSuccessCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- getEventDrainSuccessCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getEventFromTransactionEvent(TransactionEventRecord) - Static method in class org.apache.flume.channel.file.EventUtils
-
Returns the Event encapsulated by a Put wrapper
- getEventId() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
-
- getEventOrBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
required .FlumeEvent event = 1;
- getEventOrBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
required .FlumeEvent event = 1;
- getEventOrBuilder() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.PutOrBuilder
-
required .FlumeEvent event = 1;
- getEventPutAttemptCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- getEventPutAttemptCount() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
-
- getEventPutAttemptCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getEventPutErrorCount() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- getEventPutErrorCount() - Method in interface org.apache.flume.channel.file.instrumentation.FileChannelCounterMBean
-
A count of the number of IOExceptions encountered while trying to put() onto the channel.
- getEventPutSuccessCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- getEventPutSuccessCount() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
-
- getEventPutSuccessCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getEventReceivedCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getEventReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- getEventReceivedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
-
- getEvents(HttpServletRequest) - Method in class org.apache.flume.sink.solr.morphline.BlobHandler
-
- getEvents(HttpServletRequest) - Method in class org.apache.flume.source.http.BLOBHandler
-
Takes an HttpServletRequest and returns a list of Flume
Events.
- getEvents(HttpServletRequest) - Method in interface org.apache.flume.source.http.HTTPSourceHandler
-
Takes an HttpServletRequest and returns a list of Flume
Events.
- getEvents(HttpServletRequest) - Method in class org.apache.flume.source.http.JSONHandler
-
Takes an HttpServletRequest and returns a list of Flume
Events.
- getEvents() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- getEventsIterator() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- getEventSize() - Method in class org.apache.flume.source.SyslogUtils
-
- getEventsSize() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- getEventTakeAttemptCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- getEventTakeAttemptCount() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
-
- getEventTakeAttemptCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getEventTakeErrorCount() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- getEventTakeErrorCount() - Method in interface org.apache.flume.channel.file.instrumentation.FileChannelCounterMBean
-
A count of the number of errors encountered while trying to take() from the channel,
including IOExceptions and corruption-related errors.
- getEventTakeSuccessCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- getEventTakeSuccessCount() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
-
- getEventTakeSuccessCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getEvt() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- getExtension() - Method in class org.apache.flume.formatter.output.DefaultPathManager
-
- getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
-
- getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
-
- getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
-
- getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
-
- getFieldName() - Method in enum org.apache.flume.source.scribe.LogEntry._Fields
-
- getFieldName() - Method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
-
- getFieldName() - Method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
-
- getFieldName() - Method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
-
- getFieldName() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
-
- getFieldName() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
-
- getFieldName() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
-
- getFieldName() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
-
- getFields() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- getFieldsSize() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- getFieldValue(ThriftFlumeEvent._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- getFieldValue(ThriftFlumeEventServer.append_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- getFieldValue(ThriftFlumeEventServer.close_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
-
- getFieldValue(ThriftFlumeEventServer.close_result._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
-
- getFieldValue(LogEntry._Fields) - Method in class org.apache.flume.source.scribe.LogEntry
-
- getFieldValue(Scribe.Log_args._Fields) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- getFieldValue(Scribe.Log_result._Fields) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
- getFieldValue(ThriftFlumeEvent._Fields) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- getFieldValue(ThriftSourceProtocol.append_args._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- getFieldValue(ThriftSourceProtocol.append_result._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- getFieldValue(ThriftSourceProtocol.appendBatch_args._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- getFieldValue(ThriftSourceProtocol.appendBatch_result._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- getFileGroup() - Method in class org.apache.flume.source.taildir.TaildirMatcher
-
- getFileHandle() - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
-
- getFileID() - Method in class org.apache.flume.channel.file.LogRecord
-
- getFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
required sfixed32 fileID = 1;
- getFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
required sfixed32 fileID = 1;
- getFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TakeOrBuilder
-
required sfixed32 fileID = 1;
- getFileIndex() - Method in class org.apache.flume.formatter.output.DefaultPathManager
-
- getFlumeConfiguration() - Method in class org.apache.flume.node.AbstractConfigurationProvider
-
- getFlumeConfiguration() - Method in class org.apache.flume.node.PollingZooKeeperConfigurationProvider
-
- getFlumeConfiguration() - Method in class org.apache.flume.node.PropertiesFileConfigurationProvider
-
- getFlumeConfiguration() - Method in class org.apache.flume.node.StaticZooKeeperConfigurationProvider
-
- getFsDesiredReplication() - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
-
- getHandler(DatabaseType, DataSource) - Static method in class org.apache.flume.channel.jdbc.impl.SchemaHandlerFactory
-
- getHeaderEntries() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
-
- getHeaders(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- getHeaders(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
repeated .FlumeEventHeader headers = 1;
- getHeaders(int) - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
-
repeated .FlumeEventHeader headers = 1;
- getHeaders() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
-
- getHeaders() - Method in interface org.apache.flume.Event
-
Returns a map of name-value pairs describing the data stored in the body.
- getHeaders() - Method in class org.apache.flume.event.JSONEvent
-
- getHeaders() - Method in class org.apache.flume.event.SimpleEvent
-
- getHeaders() - Method in class org.apache.flume.source.taildir.TailFile
-
- getHeaders() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- getHeadersBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- getHeadersBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- getHeadersCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- getHeadersCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
repeated .FlumeEventHeader headers = 1;
- getHeadersCount() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
-
repeated .FlumeEventHeader headers = 1;
- getHeadersList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- getHeadersList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
repeated .FlumeEventHeader headers = 1;
- getHeadersList() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
-
repeated .FlumeEventHeader headers = 1;
- getHeadersOrBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- getHeadersOrBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
repeated .FlumeEventHeader headers = 1;
- getHeadersOrBuilder(int) - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
-
repeated .FlumeEventHeader headers = 1;
- getHeadersOrBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- getHeadersOrBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
repeated .FlumeEventHeader headers = 1;
- getHeadersOrBuilderList() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
-
repeated .FlumeEventHeader headers = 1;
- getHeadersSize() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- getHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- getHostInfoList(Properties) - Static method in class org.apache.flume.api.HostInfo
-
- getHostName() - Method in class org.apache.flume.api.HostInfo
-
- getId() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
-
- getIncrements() - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
-
Get the increments that should be made in hbase as a result of this
event.
- getIncrements() - Method in interface org.apache.flume.sink.hbase.HbaseEventSerializer
-
- getIncrements() - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- getIncrements() - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
-
- getIncrements() - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
-
- getIndexList() - Method in class org.apache.flume.util.OrderSelector
-
- getIndexName(String, long) - Method in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
-
Gets the name of the index to use for an index request
- getIndexName(Event) - Method in interface org.apache.flume.sink.elasticsearch.IndexNameBuilder
-
Gets the name of the index to use for an index request
- getIndexName(Event) - Method in class org.apache.flume.sink.elasticsearch.SimpleIndexNameBuilder
-
- getIndexName(Event) - Method in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
-
Gets the name of the index to use for an index request
- getIndexPrefix(Event) - Method in interface org.apache.flume.sink.elasticsearch.IndexNameBuilder
-
Gets the prefix of index to use for an index request.
- getIndexPrefix(Event) - Method in class org.apache.flume.sink.elasticsearch.SimpleIndexNameBuilder
-
- getIndexPrefix(Event) - Method in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
-
- getInode() - Method in class org.apache.flume.source.taildir.TailFile
-
- getInstance(Properties) - Static method in class org.apache.flume.api.RpcClientFactory
-
Returns an instance of
RpcClient
, optionally with failover.
- getInstance(File) - Static method in class org.apache.flume.api.RpcClientFactory
-
- getInstance(String, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
-
Deprecated.
- getInstance(String, Integer, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
-
Deprecated.
- getInstance(String, Context) - Static method in class org.apache.flume.channel.file.encryption.KeyProviderFactory
-
- getInstance(String, Context) - Static method in class org.apache.flume.formatter.output.PathManagerFactory
-
- getInstance(File, String) - Static method in class org.apache.flume.serialization.DurablePositionTracker
-
If the file exists at startup, then read it, roll it, and open a new one.
- getInstance(String, Context, ResettableInputStream) - Static method in class org.apache.flume.serialization.EventDeserializerFactory
-
- getInstance(String, Context, OutputStream) - Static method in class org.apache.flume.serialization.EventSerializerFactory
-
- getInteger(String, Integer) - Method in class org.apache.flume.Context
-
Gets value mapped to key, returning defaultValue if unmapped.
- getInteger(String) - Method in class org.apache.flume.Context
-
Gets value mapped to key, returning null if unmapped.
- GetJavaProperty - Class in org.apache.flume.tools
-
A generic way for querying Java properties.
- GetJavaProperty() - Constructor for class org.apache.flume.tools.GetJavaProperty
-
- getKafkaCommitTimer() - Method in class org.apache.flume.instrumentation.kafka.KafkaChannelCounter
-
- getKafkaCommitTimer() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getKafkaCommitTimer() - Method in class org.apache.flume.instrumentation.kafka.KafkaSourceCounter
-
- getKafkaCommitTimer() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getKafkaEmptyCount() - Method in class org.apache.flume.instrumentation.kafka.KafkaSourceCounter
-
- getKafkaEmptyCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getKafkaEventGetTimer() - Method in class org.apache.flume.instrumentation.kafka.KafkaChannelCounter
-
- getKafkaEventGetTimer() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getKafkaEventGetTimer() - Method in class org.apache.flume.instrumentation.kafka.KafkaSourceCounter
-
- getKafkaEventGetTimer() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getKafkaEventSendTimer() - Method in class org.apache.flume.instrumentation.kafka.KafkaChannelCounter
-
- getKafkaEventSendTimer() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getKafkaEventSendTimer() - Method in class org.apache.flume.instrumentation.kafka.KafkaSinkCounter
-
- getKafkaEventSendTimer() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getKafkaProps() - Method in class org.apache.flume.sink.kafka.KafkaSink
-
- getKey(String) - Method in class org.apache.flume.channel.file.encryption.JCEFileKeyProvider
-
- getKey(String) - Method in class org.apache.flume.channel.file.encryption.KeyProvider
-
Returns a non-null Key
- getKey() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
required string key = 1;
- getKey() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
required string key = 1;
- getKey() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
-
required string key = 1;
- getKey() - Method in class org.apache.flume.conf.FlumeConfigurationError
-
- getKey() - Method in class org.apache.flume.sink.hdfs.SequenceFileSerializer.Record
-
- getKeyAlias() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string keyAlias = 2;
- getKeyAlias() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
required string keyAlias = 2;
- getKeyAlias() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
-
required string keyAlias = 2;
- getKeyAliasBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string keyAlias = 2;
- getKeyAliasBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
required string keyAlias = 2;
- getKeyAliasBytes() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
-
required string keyAlias = 2;
- getKeyBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
required string key = 1;
- getKeyBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
required string key = 1;
- getKeyBytes() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
-
required string key = 1;
- getKeyClass() - Method in class org.apache.flume.sink.hdfs.HDFSTextSerializer
-
- getKeyClass() - Method in class org.apache.flume.sink.hdfs.HDFSWritableSerializer
-
- getKeyClass() - Method in interface org.apache.flume.sink.hdfs.SequenceFileSerializer
-
- getKeyProvider() - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
-
- getKeyTab() - Method in class org.apache.flume.auth.KerberosUser
-
- getKeyTab() - Method in class org.apache.flume.sink.hdfs.KerberosUser
-
- getLastConnectedServerAddress() - Method in class org.apache.flume.api.FailoverRpcClient
-
Get the last socket address this client connected to.
- getLastFileRead() - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader
-
- getLastUpdated() - Method in class org.apache.flume.source.taildir.TailFile
-
- getLifecycleState() - Method in class org.apache.flume.channel.AbstractChannel
-
- getLifecycleState() - Method in interface org.apache.flume.lifecycle.LifecycleAware
-
Return the current state of the service or component.
- getLifecycleState() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
-
- getLifecycleState() - Method in class org.apache.flume.node.PollingPropertiesFileConfigurationProvider
-
- getLifecycleState() - Method in class org.apache.flume.node.PollingZooKeeperConfigurationProvider
-
- getLifecycleState() - Method in class org.apache.flume.sink.AbstractSink
-
- getLifecycleState() - Method in class org.apache.flume.sink.AbstractSinkProcessor
-
- getLifecycleState() - Method in class org.apache.flume.sink.AbstractSinkSelector
-
- getLifecycleState() - Method in class org.apache.flume.sink.DefaultSinkProcessor
-
- getLifecycleState() - Method in class org.apache.flume.SinkRunner
-
- getLifecycleState() - Method in class org.apache.flume.source.AbstractSource
-
- getLifecycleState() - Method in class org.apache.flume.source.BasicSourceSemantics
-
- getLifecycleState() - Method in class org.apache.flume.source.EventDrivenSourceRunner
-
- getLifecycleState() - Method in class org.apache.flume.source.PollableSourceRunner
-
- getLineReadPos() - Method in class org.apache.flume.source.taildir.TailFile
-
- getLocalClient(String, ElasticSearchEventSerializer, ElasticSearchIndexRequestBuilderFactory) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchClientFactory
-
Used for tests only.
- getLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
required sfixed32 logFileID = 1;
- getLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
required sfixed32 logFileID = 1;
- getLogFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.ActiveLogOrBuilder
-
required sfixed32 logFileID = 1;
- getLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed32 logFileID = 2;
- getLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
required sfixed32 logFileID = 2;
- getLogFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
required sfixed32 logFileID = 2;
- getLong(String, Long) - Method in class org.apache.flume.Context
-
Gets value mapped to key, returning defaultValue if unmapped.
- getLong(String) - Method in class org.apache.flume.Context
-
Gets value mapped to key, returning null if unmapped.
- getMarkPosition() - Method in interface org.apache.flume.serialization.RemoteMarkable
-
Return the saved mark position without moving the mark pointer.
- getMarkPosition() - Method in class org.apache.flume.serialization.ResettableFileInputStream
-
- getMaxBackOffSleepInterval() - Method in interface org.apache.flume.PollableSource
-
- getMaxBackOffSleepInterval() - Method in class org.apache.flume.source.AbstractPollableSource
-
- getMaxBackOffSleepInterval() - Method in class org.apache.flume.source.taildir.TaildirSource
-
- getMaxMemQueueSize() - Method in class org.apache.flume.channel.SpillableMemoryChannel
-
- getMaxTimeOut() - Method in class org.apache.flume.util.OrderSelector
-
- getMaxTries() - Method in class org.apache.flume.api.FailoverRpcClient
-
Get the maximum number of "failed" hosts the client will try to establish
connection to before throwing an exception.
- getMemoryCapacity() - Method in class org.apache.flume.channel.SpillableMemoryChannel
-
- getMessage() - Method in class org.apache.flume.source.scribe.LogEntry
-
- getMessages() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- getMessagesIterator() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- getMessagesSize() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- getMonitorClass() - Method in enum org.apache.flume.instrumentation.MonitoringType
-
- getName() - Method in class org.apache.flume.channel.AbstractChannel
-
- getName() - Method in class org.apache.flume.channel.AbstractChannelSelector
-
- getName() - Method in enum org.apache.flume.channel.jdbc.DatabaseType
-
- getName() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
-
- getName() - Method in enum org.apache.flume.channel.jdbc.TransactionIsolation
-
- getName() - Method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
-
- getName() - Method in class org.apache.flume.CounterGroup
-
- getName() - Method in interface org.apache.flume.NamedComponent
-
- getName() - Method in class org.apache.flume.sink.AbstractSink
-
- getName() - Method in class org.apache.flume.source.AbstractSource
-
- getName() - Method in class org.apache.flume.source.BasicSourceSemantics
-
- getNames() - Static method in enum org.apache.flume.tools.FlumeToolType
-
- getNameString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
-
- getNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- getNanoTimestampKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
-
- getNumCurrentReplicas() - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
-
This method gets the datanode replication count for the current open file.
- getObjects() - Method in class org.apache.flume.util.OrderSelector
-
Get the list of objects to be ordered.
- getOffset() - Method in class org.apache.flume.channel.file.LogRecord
-
- getOffset() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
required sfixed32 offset = 2;
- getOffset() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
required sfixed32 offset = 2;
- getOffset() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TakeOrBuilder
-
required sfixed32 offset = 2;
- getOpenConnectionCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getOpenConnectionCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- getOpenConnectionCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
-
- getOptionalChannels(Event) - Method in class org.apache.flume.channel.MultiplexingChannelSelector
-
- getOptionalChannels(Event) - Method in class org.apache.flume.channel.ReplicatingChannelSelector
-
- getOptionalChannels(Event) - Method in interface org.apache.flume.ChannelSelector
-
Returns a list of optional channels.
- getOutputStream() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
-
Returns the stream to serialize data into.
- getOutputStream() - Method in class org.apache.flume.serialization.FlumeEventAvroEventSerializer
-
- getOverflowCapacity() - Method in class org.apache.flume.channel.SpillableMemoryChannel
-
- getOverflowTimeout() - Method in class org.apache.flume.channel.SpillableMemoryChannel
-
- getParameters() - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor
-
- getParameters() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
optional bytes parameters = 3;
- getParameters() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
optional bytes parameters = 3;
- getParameters() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
-
optional bytes parameters = 3;
- getParameters() - Method in class org.apache.flume.Context
-
Gets a copy of the backing map structure.
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
-
- getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
- getPath() - Method in class org.apache.flume.source.taildir.TailFile
-
- getPolicy() - Method in class org.apache.flume.SinkRunner
-
- getPollFrequency() - Method in class org.apache.flume.instrumentation.GangliaServer
-
- getPortNumber() - Method in class org.apache.flume.api.HostInfo
-
- getPos() - Method in class org.apache.flume.source.taildir.TailFile
-
- getPosition() - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
-
- getPosition() - Method in class org.apache.flume.serialization.DurablePositionTracker
-
- getPosition() - Method in interface org.apache.flume.serialization.PositionTracker
-
- getPostvalidationConfig() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getPrefix() - Method in class org.apache.flume.formatter.output.DefaultPathManager
-
- getPrefix() - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
-
- getPrevalidationConfig() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getPrincipal() - Method in class org.apache.flume.auth.KerberosUser
-
- getPrincipal() - Method in class org.apache.flume.sink.hdfs.KerberosUser
-
- getPriority() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- getProcessor() - Method in class org.apache.flume.sink.SinkGroup
-
- getProcessor(Context, List<Sink>) - Static method in class org.apache.flume.sink.SinkProcessorFactory
-
Creates a sink processor and configures it using the provided context
- getProcessor(ComponentConfiguration, List<Sink>) - Static method in class org.apache.flume.sink.SinkProcessorFactory
-
- getProcessorContext() - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
-
- getProducerProps() - Method in class org.apache.flume.channel.kafka.KafkaChannel
-
- getProperty(String) - Method in class org.apache.flume.node.EnvVarResolverProperties
-
- getProvider(Context, String) - Static method in class org.apache.flume.channel.jdbc.JdbcChannelProviderFactory
-
- getProviderClass() - Method in enum org.apache.flume.channel.file.encryption.CipherProviderType
-
- getPutCount() - Method in class org.apache.flume.channel.file.Log
-
- getQueueHead() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 queueHead = 4;
- getQueueHead() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
required sfixed32 queueHead = 4;
- getQueueHead() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
required sfixed32 queueHead = 4;
- getQueueSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 queueSize = 3;
- getQueueSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
required sfixed32 queueSize = 3;
- getQueueSize() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
required sfixed32 queueSize = 3;
- getRaf() - Method in class org.apache.flume.source.taildir.TailFile
-
- getRandomKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
-
- getReadCount() - Method in class org.apache.flume.channel.file.Log
-
- getRecursiveDirectorySearch() - Method in class org.apache.flume.source.SpoolDirectorySource
-
- getReferenceName() - Method in class org.apache.flume.api.HostInfo
-
- getRequiredChannels(Event) - Method in class org.apache.flume.channel.MultiplexingChannelSelector
-
- getRequiredChannels(Event) - Method in class org.apache.flume.channel.ReplicatingChannelSelector
-
- getRequiredChannels(Event) - Method in interface org.apache.flume.ChannelSelector
-
Returns a list of required channels.
- getResult() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.append_call
-
- getResult() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
-
- getResult(I, ThriftFlumeEventServer.append_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor.append
-
- getResult(I, ThriftFlumeEventServer.close_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor.close
-
- getResult() - Method in class org.apache.flume.source.scribe.Scribe.AsyncClient.Log_call
-
- getResult(I, Scribe.Log_args) - Method in class org.apache.flume.source.scribe.Scribe.Processor.Log
-
- getResult() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.append_call
-
- getResult() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.appendBatch_call
-
- getResult(I, ThriftSourceProtocol.append_args) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Processor.append
-
- getResult(I, ThriftSourceProtocol.appendBatch_args) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Processor.appendBatch
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor.append
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor.close
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.flume.source.scribe.Scribe.AsyncProcessor.Log
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor.append
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor.appendBatch
-
- getRevision() - Static method in class org.apache.flume.tools.VersionInfo
-
Get the subversion revision number for the root directory
- getRollbackCount() - Method in class org.apache.flume.channel.file.Log
-
- getRollbackCount() - Method in class org.apache.flume.instrumentation.kafka.KafkaChannelCounter
-
- getRollbackCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getRollbackCount() - Method in class org.apache.flume.instrumentation.kafka.KafkaSinkCounter
-
- getRollbackCount() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getRollInterval() - Method in class org.apache.flume.sink.RollingFileSink
-
- getRowKey(Calendar) - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
Returns a row-key with the following format:
[time in millis]-[random key]-[nonce]
- getRowKey() - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- getSaslGssCallbackHandler() - Static method in class org.apache.flume.auth.FlumeAuthenticationUtil
-
Returns the standard SaslGssCallbackHandler from the hadoop common module
- getSchema() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
-
Returns the parsed Avro schema corresponding to the data being written
and the parameterized type specified.
- getSchema() - Method in class org.apache.flume.serialization.FlumeEventAvroEventSerializer
-
- getSelector() - Method in class org.apache.flume.channel.ChannelProcessor
-
- getSelectorConfiguration() - Method in class org.apache.flume.conf.source.SourceConfiguration
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
-
- getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
- getSeriesTimestamp() - Method in class org.apache.flume.formatter.output.DefaultPathManager
-
- getSimpleDateFormat(String) - Static method in class org.apache.flume.formatter.output.BucketPath
-
- getSinkClassName() - Method in enum org.apache.flume.conf.sink.SinkType
-
- getSinkConfigMap() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getSinkConfigurationType() - Method in enum org.apache.flume.conf.sink.SinkConfiguration.SinkConfigurationType
-
- getSinkContext() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getSinkGroupConfigMap() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getSinkgroupSet() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getSinkProcessorClassName() - Method in enum org.apache.flume.conf.sink.SinkProcessorType
-
- getSinkProcessorConfiguration() - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
-
- getSinkProcessorConfigurationType() - Method in enum org.apache.flume.conf.sink.SinkProcessorConfiguration.SinkProcessorConfigurationType
-
- getSinkRunners() - Method in interface org.apache.flume.node.MaterializedConfiguration
-
- getSinkRunners() - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
-
- getSinks() - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
-
- getSinks() - Method in class org.apache.flume.conf.sink.SinkProcessorConfiguration
-
- getSinks() - Method in class org.apache.flume.sink.AbstractSinkProcessor
-
- getSinks() - Method in class org.apache.flume.sink.AbstractSinkSelector
-
- getSinkSet() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getSource() - Method in class org.apache.flume.SourceRunner
-
- getSourceClassName() - Method in enum org.apache.flume.conf.source.SourceType
-
- getSourceConfigMap() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getSourceConfigurationType() - Method in enum org.apache.flume.conf.source.SourceConfiguration.SourceConfigurationType
-
- getSourceContext() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getSourceCounter() - Method in class org.apache.flume.source.SpoolDirectorySource
-
- getSourceCounter() - Method in class org.apache.flume.source.taildir.TaildirSource
-
- getSourcePort() - Method in class org.apache.flume.source.NetcatUdpSource
-
- getSourceRunners() - Method in interface org.apache.flume.node.MaterializedConfiguration
-
- getSourceRunners() - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
-
- getSourceSet() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
-
- getSpill() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
-
- getSpillPayload() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
-
- getSrcChecksum() - Static method in class org.apache.flume.tools.VersionInfo
-
Get the checksum of the source files from which Flume was
built.
- getStartException() - Method in class org.apache.flume.source.BasicSourceSemantics
-
- getStartTime() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
-
- getStartTime() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getStartTime() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getStartTime() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getStartTime() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
-
Returns when this component was first started
- getStartTime() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getStartTime() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
-
- getState() - Method in class org.apache.flume.channel.BasicTransactionSemantics
-
- getStopTime() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
-
- getStopTime() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getStopTime() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getStopTime() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getStopTime() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
-
Returns when this component was stopped
- getStopTime() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getStopTime() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
-
- getString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
-
- getString(String, String) - Method in class org.apache.flume.Context
-
Gets value mapped to key, returning defaultValue if unmapped.
- getString(String) - Method in class org.apache.flume.Context
-
Gets value mapped to key, returning null if unmapped.
- getSubProperties(String) - Method in class org.apache.flume.Context
-
Get properties which start with a prefix.
- getSuccess() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
- getSuccess() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- getSuccess() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- getSyslogStatus() - Method in enum org.apache.flume.source.SyslogUtils.SyslogStatus
-
- getTailFiles() - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader
-
- getTakeCount() - Method in class org.apache.flume.channel.file.Log
-
- getTarget() - Method in class org.apache.flume.serialization.DurablePositionTracker
-
- getTarget() - Method in interface org.apache.flume.serialization.PositionTracker
-
- getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
-
- getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
-
- getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
-
- getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.flume.source.scribe.LogEntry._Fields
-
- getThriftFieldId() - Method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
-
- getThriftFieldId() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
-
- getThriftInstance(String, Integer, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
-
Return an
RpcClient that uses Thrift for communicating with
the next hop.
- getThriftInstance(String, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
-
Return an
RpcClient that uses Thrift for communicating with
the next hop.
- getThriftInstance(Properties) - Static method in class org.apache.flume.api.RpcClientFactory
-
Return an
RpcClient that uses Thrift for communicating with
the next hop.
- getThriftInstance(Properties) - Static method in class org.apache.flume.api.SecureRpcClientFactory
-
Return a secure
RpcClient that uses Thrift for communicating
with the next hop.
- getTimeout() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
- getTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- getTimestampKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
-
- getTopic() - Method in class org.apache.flume.sink.kafka.KafkaSink
-
- getTotalStored() - Method in class org.apache.flume.channel.SpillableMemoryChannel
-
- getTransaction() - Method in class org.apache.flume.channel.BasicChannelSemantics
-
Initializes the channel if it is not already, then checks to see
if there is an open transaction for this thread, creating a new
one via createTransaction
if not.
- getTransaction() - Method in interface org.apache.flume.Channel
-
- getTransaction() - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
-
- getTransaction() - Method in class org.apache.flume.channel.jdbc.JdbcChannel
-
- getTransaction() - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
-
- getTransaction() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
-
- getTransactionID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed64 transactionID = 2;
- getTransactionID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
required sfixed64 transactionID = 2;
- getTransactionID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
-
required sfixed64 transactionID = 2;
- getTransport(TSocket) - Method in class org.apache.flume.api.SecureThriftRpcClient
-
- getTransport(TSocket) - Method in class org.apache.flume.api.ThriftRpcClient
-
- getType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
required sfixed32 type = 1;
- getType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
-
required sfixed32 type = 1;
- getType() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CommitOrBuilder
-
required sfixed32 type = 1;
- getType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed32 type = 1;
- getType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
required sfixed32 type = 1;
- getType() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
-
required sfixed32 type = 1;
- getType() - Method in class org.apache.flume.conf.ComponentConfiguration
-
- getType() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
-
- getType() - Method in interface org.apache.flume.instrumentation.kafka.KafkaChannelCounterMBean
-
- getType() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSinkCounterMBean
-
- getType() - Method in interface org.apache.flume.instrumentation.kafka.KafkaSourceCounterMBean
-
- getType() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
-
- getType() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
-
- getType() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
-
- getUnhealthy() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- getUnhealthy() - Method in interface org.apache.flume.channel.file.instrumentation.FileChannelCounterMBean
-
A value of 0 represents that the channel is in a healthy state: it is either starting
up (i.e.
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
-
- getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
- getUnsafeMode() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
- getUrl() - Static method in class org.apache.flume.tools.VersionInfo
-
Get the subversion URL for the root Flume directory.
- getUser() - Static method in class org.apache.flume.tools.VersionInfo
-
The user that compiled Flume.
- getUUIDKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
-
- getValidationQuery() - Method in enum org.apache.flume.channel.jdbc.DatabaseType
-
- getValue() - Method in enum com.cloudera.flume.handlers.thrift.EventStatus
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum com.cloudera.flume.handlers.thrift.Priority
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
optional string value = 2;
- getValue() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
optional string value = 2;
- getValue() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
-
optional string value = 2;
- getValue() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
-
- getValue() - Method in class org.apache.flume.sink.hdfs.SequenceFileSerializer.Record
-
- getValue() - Method in enum org.apache.flume.source.scribe.ResultCode
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.flume.thrift.Status
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValueBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
optional string value = 2;
- getValueBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
optional string value = 2;
- getValueBytes() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
-
optional string value = 2;
- getValueClass() - Method in class org.apache.flume.sink.hdfs.HDFSTextSerializer
-
- getValueClass() - Method in class org.apache.flume.sink.hdfs.HDFSWritableSerializer
-
- getValueClass() - Method in interface org.apache.flume.sink.hdfs.SequenceFileSerializer
-
- getValueString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
-
- getVersion() - Method in class org.apache.flume.channel.file.LogFileV3.SequentialReader
-
- getVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 version = 1;
- getVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
required sfixed32 version = 1;
- getVersion() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
required sfixed32 version = 1;
- getVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed32 version = 1;
- getVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
required sfixed32 version = 1;
- getVersion() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
required sfixed32 version = 1;
- getVersion() - Static method in class org.apache.flume.tools.VersionInfo
-
Get the Flume version.
- getWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed64 writeOrderID = 2;
- getWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
required sfixed64 writeOrderID = 2;
- getWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
required sfixed64 writeOrderID = 2;
- getWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed64 writeOrderID = 3;
- getWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
required sfixed64 writeOrderID = 3;
- getWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
-
required sfixed64 writeOrderID = 3;
- getWriter(String) - Method in class org.apache.flume.sink.hdfs.HDFSWriterFactory
-
- GROUP_ID_FLUME - Static variable in class org.apache.flume.channel.kafka.KafkaChannelConfiguration
-
- handle(Event, Throwable) - Method in interface org.apache.flume.sink.kite.policy.FailurePolicy
-
Handle a non-recoverable event.
- handle(Event, Throwable) - Method in class org.apache.flume.sink.kite.policy.RetryPolicy
-
- handle(Event, Throwable) - Method in class org.apache.flume.sink.kite.policy.SavePolicy
-
- handleConfigurationEvent(MaterializedConfiguration) - Method in class org.apache.flume.node.Application
-
- HANDLER_CLASS - Static variable in class org.apache.flume.sink.solr.morphline.MorphlineSink
-
- hasBackupCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional sfixed64 backupCheckpointPosition = 6;
- hasBackupCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
optional sfixed64 backupCheckpointPosition = 6;
- hasBackupCheckpointPosition() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
optional sfixed64 backupCheckpointPosition = 6;
- hasBackupCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional sfixed64 backupCheckpointWriteOrderID = 7;
- hasBackupCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
optional sfixed64 backupCheckpointWriteOrderID = 7;
- hasBackupCheckpointWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
optional sfixed64 backupCheckpointWriteOrderID = 7;
- hasBody() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
required bytes body = 2;
- hasBody() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
required bytes body = 2;
- hasBody() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
-
required bytes body = 2;
- hasCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed64 checkpointPosition = 3;
- hasCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
required sfixed64 checkpointPosition = 3;
- hasCheckpointPosition() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
required sfixed64 checkpointPosition = 3;
- hasCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed64 checkpointWriteOrderID = 4;
- hasCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
required sfixed64 checkpointWriteOrderID = 4;
- hasCheckpointWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
required sfixed64 checkpointWriteOrderID = 4;
- hasChecksum() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
optional sfixed64 checksum = 2;
- hasChecksum() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
optional sfixed64 checksum = 2;
- hasChecksum() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.PutOrBuilder
-
optional sfixed64 checksum = 2;
- hasCipherProvider() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string cipherProvider = 1;
- hasCipherProvider() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
required string cipherProvider = 1;
- hasCipherProvider() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
-
required string cipherProvider = 1;
- hasCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
required sfixed32 count = 2;
- hasCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
required sfixed32 count = 2;
- hasCount() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.ActiveLogOrBuilder
-
required sfixed32 count = 2;
- hasEncryption() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional .LogFileEncryption encryption = 5;
- hasEncryption() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
optional .LogFileEncryption encryption = 5;
- hasEncryption() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
optional .LogFileEncryption encryption = 5;
- hasEvent() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
required .FlumeEvent event = 1;
- hasEvent() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
required .FlumeEvent event = 1;
- hasEvent() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.PutOrBuilder
-
required .FlumeEvent event = 1;
- hasFatalError() - Method in class org.apache.flume.source.SpoolDirectorySource
-
- hasFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
required sfixed32 fileID = 1;
- hasFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
required sfixed32 fileID = 1;
- hasFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TakeOrBuilder
-
required sfixed32 fileID = 1;
- hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
-
- hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
-
- hashCode() - Method in class org.apache.flume.auth.KerberosUser
-
- hashCode() - Method in class org.apache.flume.sink.hdfs.KerberosUser
-
- hashCode() - Method in class org.apache.flume.source.scribe.LogEntry
-
- hashCode() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- hashCode() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
- hashCode() - Method in class org.apache.flume.source.taildir.TaildirMatcher
-
- hashCode() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- hashCode() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- hashCode() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- hashCode() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- hashCode() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- hasKey() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
required string key = 1;
- hasKey() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
required string key = 1;
- hasKey() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
-
required string key = 1;
- hasKeyAlias() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string keyAlias = 2;
- hasKeyAlias() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
required string keyAlias = 2;
- hasKeyAlias() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
-
required string keyAlias = 2;
- hasLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
required sfixed32 logFileID = 1;
- hasLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
required sfixed32 logFileID = 1;
- hasLogFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.ActiveLogOrBuilder
-
required sfixed32 logFileID = 1;
- hasLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed32 logFileID = 2;
- hasLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
required sfixed32 logFileID = 2;
- hasLogFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
required sfixed32 logFileID = 2;
- hasNext() - Method in class org.apache.flume.util.SpecificOrderIterator
-
- hasOffset() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
required sfixed32 offset = 2;
- hasOffset() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
required sfixed32 offset = 2;
- hasOffset() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TakeOrBuilder
-
required sfixed32 offset = 2;
- hasParameters() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
optional bytes parameters = 3;
- hasParameters() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
optional bytes parameters = 3;
- hasParameters() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
-
optional bytes parameters = 3;
- hasQueueHead() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 queueHead = 4;
- hasQueueHead() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
required sfixed32 queueHead = 4;
- hasQueueHead() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
required sfixed32 queueHead = 4;
- hasQueueSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 queueSize = 3;
- hasQueueSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
required sfixed32 queueSize = 3;
- hasQueueSize() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
required sfixed32 queueSize = 3;
- hasSpill() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
-
- hasTransactionID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed64 transactionID = 2;
- hasTransactionID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
required sfixed64 transactionID = 2;
- hasTransactionID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
-
required sfixed64 transactionID = 2;
- hasType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
required sfixed32 type = 1;
- hasType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
-
required sfixed32 type = 1;
- hasType() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CommitOrBuilder
-
required sfixed32 type = 1;
- hasType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed32 type = 1;
- hasType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
required sfixed32 type = 1;
- hasType() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
-
required sfixed32 type = 1;
- hasValue() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
optional string value = 2;
- hasValue() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
optional string value = 2;
- hasValue() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
-
optional string value = 2;
- hasVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 version = 1;
- hasVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
required sfixed32 version = 1;
- hasVersion() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
required sfixed32 version = 1;
- hasVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed32 version = 1;
- hasVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
required sfixed32 version = 1;
- hasVersion() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
-
required sfixed32 version = 1;
- hasWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed64 writeOrderID = 2;
- hasWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
required sfixed64 writeOrderID = 2;
- hasWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
-
required sfixed64 writeOrderID = 2;
- hasWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed64 writeOrderID = 3;
- hasWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
required sfixed64 writeOrderID = 3;
- hasWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
-
required sfixed64 writeOrderID = 3;
- HbaseEventSerializer - Interface in org.apache.flume.sink.hbase
-
Interface for an event serializer which serializes the headers and body
of an event to write them to hbase.
- HBaseSink - Class in org.apache.flume.sink.hbase
-
A simple sink which reads events from a channel and writes them to HBase.
- HBaseSink() - Constructor for class org.apache.flume.sink.hbase.HBaseSink
-
- HBaseSink(Configuration) - Constructor for class org.apache.flume.sink.hbase.HBaseSink
-
- HBaseSinkConfigurationConstants - Class in org.apache.flume.sink.hbase
-
Constants used for configuration of HBaseSink and AsyncHBaseSink
- HBaseSinkConfigurationConstants() - Constructor for class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
-
- HDFSCompressedDataStream - Class in org.apache.flume.sink.hdfs
-
- HDFSCompressedDataStream() - Constructor for class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
-
- HDFSDataStream - Class in org.apache.flume.sink.hdfs
-
- HDFSDataStream() - Constructor for class org.apache.flume.sink.hdfs.HDFSDataStream
-
- HDFSEventSink - Class in org.apache.flume.sink.hdfs
-
- HDFSEventSink() - Constructor for class org.apache.flume.sink.hdfs.HDFSEventSink
-
- HDFSEventSink(HDFSWriterFactory) - Constructor for class org.apache.flume.sink.hdfs.HDFSEventSink
-
- HDFSEventSink.WriterCallback - Interface in org.apache.flume.sink.hdfs
-
- HDFSSequenceFile - Class in org.apache.flume.sink.hdfs
-
- HDFSSequenceFile() - Constructor for class org.apache.flume.sink.hdfs.HDFSSequenceFile
-
- HDFSTextSerializer - Class in org.apache.flume.sink.hdfs
-
- HDFSTextSerializer() - Constructor for class org.apache.flume.sink.hdfs.HDFSTextSerializer
-
- HDFSTextSerializer.Builder - Class in org.apache.flume.sink.hdfs
-
- HDFSWritableSerializer - Class in org.apache.flume.sink.hdfs
-
- HDFSWritableSerializer() - Constructor for class org.apache.flume.sink.hdfs.HDFSWritableSerializer
-
- HDFSWritableSerializer.Builder - Class in org.apache.flume.sink.hdfs
-
- HDFSWriter - Interface in org.apache.flume.sink.hdfs
-
- HDFSWriterFactory - Class in org.apache.flume.sink.hdfs
-
- HDFSWriterFactory() - Constructor for class org.apache.flume.sink.hdfs.HDFSWriterFactory
-
- HEADER_NAME - Static variable in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
-
- HEADER_NAME_LENGTH_THRESHOLD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
The length of header name in bytes that will be stored inline.
- HEADER_NAME_SPILL_MAX_LENGTH - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
The maximum spill size for header names.
- HEADER_VALUE_LENGTH_THRESHOLD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
The length of header value in bytes that will be stored inline.
- HEADER_VALUE_SPILL_MAX_LENGTH - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
-
The maximum spill size for header values.
- HeaderAndBodyTextEventSerializer - Class in org.apache.flume.serialization
-
This class simply writes the body of the event to the output stream
and appends a newline after each event.
- HeaderAndBodyTextEventSerializer.Builder - Class in org.apache.flume.serialization
-
- HeaderEntry(String, String) - Constructor for class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
-
- headers - Variable in class org.apache.flume.thrift.ThriftFlumeEvent
-
- HEADERS_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
- HEADERS_PREFIX - Static variable in class org.apache.flume.source.taildir.TaildirSourceConfigurationConstants
-
Mapping for putting headers to events grouped by file groups.
- headerTable(Table<String, String, String>) - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader.Builder
-
- HEART_BEAT_INTERVAL - Static variable in class org.apache.flume.sink.hive.Config
-
- hflushOrSync(FSDataOutputStream) - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
-
If hflush is available in this version of HDFS, then this method calls
hflush, else it calls sync.
- HIVE_DATABASE - Static variable in class org.apache.flume.sink.hive.Config
-
- HIVE_METASTORE - Static variable in class org.apache.flume.sink.hive.Config
-
- HIVE_PARTITION - Static variable in class org.apache.flume.sink.hive.Config
-
- HIVE_TABLE - Static variable in class org.apache.flume.sink.hive.Config
-
- HIVE_TXNS_PER_BATCH_ASK - Static variable in class org.apache.flume.sink.hive.Config
-
- HiveDelimitedTextSerializer - Class in org.apache.flume.sink.hive
-
Forwards the incoming event body to Hive unmodified
Sets up the delimiter and the field to column mapping
- HiveDelimitedTextSerializer() - Constructor for class org.apache.flume.sink.hive.HiveDelimitedTextSerializer
-
- HiveEventSerializer - Interface in org.apache.flume.sink.hive
-
- HiveJsonSerializer - Class in org.apache.flume.sink.hive
-
Forwards the incoming event body to Hive unmodified
Sets up the delimiter and the field to column mapping
- HiveJsonSerializer() - Constructor for class org.apache.flume.sink.hive.HiveJsonSerializer
-
- HiveSink - Class in org.apache.flume.sink.hive
-
- HiveSink() - Constructor for class org.apache.flume.sink.hive.HiveSink
-
- host - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- HOST - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
-
- HOST - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
-
- HOST_HEADER - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
-
- HOST_SELECTOR_RANDOM - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
- HOST_SELECTOR_ROUND_ROBIN - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
-
- HostInfo - Class in org.apache.flume.api
-
A convenience class that holds the property reference name along with the
hostname and port number of a specified host address.
- HostInfo(String, String, int) - Constructor for class org.apache.flume.api.HostInfo
-
- HostInterceptor - Class in org.apache.flume.interceptor
-
Simple Interceptor class that sets the host name or IP on all events
that are intercepted.
- HostInterceptor.Builder - Class in org.apache.flume.interceptor
-
Builder which builds new instances of the HostInterceptor.
- HostInterceptor.Constants - Class in org.apache.flume.interceptor
-
- HOSTNAMES - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
-
Comma separated list of hostname:port, if the port is not present the
default port '9300' will be used
- HOUR - Static variable in class org.apache.flume.sink.hive.Config
-
- HTTPBadRequestException - Exception in org.apache.flume.source.http
-
Exception thrown by an HTTP Handler if the request was not parsed correctly
into an event because the request was not in the expected format.
- HTTPBadRequestException(String) - Constructor for exception org.apache.flume.source.http.HTTPBadRequestException
-
- HTTPBadRequestException(String, Throwable) - Constructor for exception org.apache.flume.source.http.HTTPBadRequestException
-
- HTTPBadRequestException(Throwable) - Constructor for exception org.apache.flume.source.http.HTTPBadRequestException
-
- HTTPMetricsServer - Class in org.apache.flume.instrumentation.http
-
A Monitor service implementation that runs a web server on a configurable
port and returns the metrics for components in JSON format.
- HTTPMetricsServer() - Constructor for class org.apache.flume.instrumentation.http.HTTPMetricsServer
-
- HTTPServerConstraintUtil - Class in org.apache.flume.tools
-
Utility class to impose constraints on Jetty HTTP servers
- HttpSink - Class in org.apache.flume.sink.http
-
Implementation of an HTTP sink.
- HttpSink() - Constructor for class org.apache.flume.sink.http.HttpSink
-
- HTTPSource - Class in org.apache.flume.source.http
-
A source which accepts Flume Events by HTTP POST and GET.
- HTTPSource() - Constructor for class org.apache.flume.source.http.HTTPSource
-
- HTTPSourceConfigurationConstants - Class in org.apache.flume.source.http
-
- HTTPSourceConfigurationConstants() - Constructor for class org.apache.flume.source.http.HTTPSourceConfigurationConstants
-
- HTTPSourceHandler - Interface in org.apache.flume.source.http
-
- IDLE_TIMEOUT - Static variable in class org.apache.flume.sink.hive.Config
-
- IDLE_TIMEOUT - Static variable in class org.apache.flume.source.taildir.TaildirSourceConfigurationConstants
-
Time (ms) to close idle files.
- IGNORE_CASE_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
Whether to ignore case when performing regex matches.
- IGNORE_CASE_DEFAULT - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- IGNORE_PAT - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
-
Pattern of files to ignore
- ignorePattern(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
-
- INCLUDE_PAT - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
-
Pattern of files to include
- includePattern(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
-
- increment(String) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
-
Atomically increments the current value for this key by one
- incrementAndGet(String) - Method in class org.apache.flume.CounterGroup
-
- incrementAppendAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- incrementAppendBatchAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- incrementAppendBatchReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- incrementAppendReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- incrementBatchCompleteCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- incrementBatchEmptyCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- incrementBatchUnderflowCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- incrementCheckpointBackupWriteErrorCount() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- incrementCheckpointWriteErrorCount() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- incrementConnectionClosedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- incrementConnectionCreatedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- incrementConnectionFailedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- incrementEventAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- incrementEventDrainAttemptCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- incrementEventDrainSuccessCount() - Method in class org.apache.flume.instrumentation.SinkCounter
-
- incrementEventPutAttemptCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- incrementEventPutErrorCount() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- incrementEventReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
-
- incrementEventTakeAttemptCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- incrementEventTakeErrorCount() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- incrementKafkaEmptyCount() - Method in class org.apache.flume.instrumentation.kafka.KafkaSourceCounter
-
- incrementPersistedEventCount() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
-
- incrementRemovedEventCount() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
-
- incrementRollbackCount() - Method in class org.apache.flume.instrumentation.kafka.KafkaSinkCounter
-
- INDENTSTEP - Static variable in class org.apache.flume.conf.FlumeConfiguration
-
- INDEX_NAME - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
-
The name to index the document to, defaults to 'flume'
- INDEX_NAME_BUILDER - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
-
The fully qualified class name of the index name builder the sink
should use to determine name of index where the event should be sent.
- INDEX_NAME_BUILDER_PREFIX - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
-
The fully qualified class name of the index name builder the sink
should use to determine name of index where the event should be sent.
- INDEX_TYPE - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
-
The type to index the document to, defaults to 'log'
- IndexNameBuilder - Interface in org.apache.flume.sink.elasticsearch
-
- informFailure(HostInfo) - Method in interface org.apache.flume.api.LoadBalancingRpcClient.HostSelector
-
- informFailure(T) - Method in class org.apache.flume.util.OrderSelector
-
Inform this class of the failure of an object so it can be backed off.
- informSinkFailed(Sink) - Method in class org.apache.flume.sink.AbstractSinkSelector
-
- informSinkFailed(Sink) - Method in interface org.apache.flume.sink.LoadBalancingSinkProcessor.SinkSelector
-
- INITIAL_CONTEXT_FACTORY - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
-
- InitialContextFactory - Class in org.apache.flume.source.jms
-
- InitialContextFactory() - Constructor for class org.apache.flume.source.jms.InitialContextFactory
-
- initialize() - Method in class org.apache.flume.channel.BasicChannelSemantics
-
Called upon first getTransaction() request, while synchronized on
this
Channel
instance.
- initialize() - Method in class org.apache.flume.channel.ChannelProcessor
-
- initialize(Context) - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
-
- initialize(Context) - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
-
Initializes the channel provider.
- initialize() - Method in class org.apache.flume.interceptor.HostInterceptor
-
- initialize() - Method in interface org.apache.flume.interceptor.Interceptor
-
Any initialization / startup needed by the Interceptor.
- initialize() - Method in class org.apache.flume.interceptor.InterceptorChain
-
- initialize() - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor
-
- initialize() - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor
-
- initialize() - Method in class org.apache.flume.interceptor.RemoveHeaderInterceptor
-
- initialize() - Method in class org.apache.flume.interceptor.SearchAndReplaceInterceptor
-
- initialize() - Method in class org.apache.flume.interceptor.StaticInterceptor
-
- initialize() - Method in class org.apache.flume.interceptor.TimestampInterceptor
-
- initialize(byte[], byte[]) - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
-
Initialize the event serializer.
- initialize(Event, byte[]) - Method in interface org.apache.flume.sink.hbase.HbaseEventSerializer
-
Initialize the event serializer.
- initialize(Event, byte[]) - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
-
- initialize(byte[], byte[]) - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
-
- initialize(Event, byte[]) - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
-
- initialize() - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor
-
- initialize() - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
-
- initializeClientAddress() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
Resolves local host address so it can be included in event headers.
- initializeRpcClient(Properties) - Method in class org.apache.flume.sink.AbstractRpcSink
-
- initializeRpcClient(Properties) - Method in class org.apache.flume.sink.AvroSink
-
- initializeRpcClient(Properties) - Method in class org.apache.flume.sink.ThriftSink
-
- initialValue() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionFactory
-
- INPUT_CHARSET - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
-
Character set used when reading the input.
- inputCharset(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
-
- intercept(Event) - Method in class org.apache.flume.interceptor.HostInterceptor
-
Modifies events in-place.
- intercept(List<Event>) - Method in class org.apache.flume.interceptor.HostInterceptor
-
- intercept(Event) - Method in interface org.apache.flume.interceptor.Interceptor
-
Interception of a single
Event
.
- intercept(List<Event>) - Method in interface org.apache.flume.interceptor.Interceptor
-
Interception of a batch of
events.
- intercept(Event) - Method in class org.apache.flume.interceptor.InterceptorChain
-
- intercept(List<Event>) - Method in class org.apache.flume.interceptor.InterceptorChain
-
- intercept(Event) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor
-
- intercept(List<Event>) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor
-
- intercept(Event) - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor
-
- intercept(List<Event>) - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor
-
- intercept(List<Event>) - Method in class org.apache.flume.interceptor.RemoveHeaderInterceptor
-
- intercept(Event) - Method in class org.apache.flume.interceptor.RemoveHeaderInterceptor
-
- intercept(Event) - Method in class org.apache.flume.interceptor.SearchAndReplaceInterceptor
-
- intercept(List<Event>) - Method in class org.apache.flume.interceptor.SearchAndReplaceInterceptor
-
- intercept(Event) - Method in class org.apache.flume.interceptor.StaticInterceptor
-
Modifies events in-place.
- intercept(List<Event>) - Method in class org.apache.flume.interceptor.StaticInterceptor
-
- intercept(Event) - Method in class org.apache.flume.interceptor.TimestampInterceptor
-
Modifies events in-place.
- intercept(List<Event>) - Method in class org.apache.flume.interceptor.TimestampInterceptor
-
- intercept(List<Event>) - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor
-
- intercept(Event) - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor
-
- intercept(Event) - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
-
- intercept(List<Event>) - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
-
- Interceptor - Interface in org.apache.flume.interceptor
-
- Interceptor.Builder - Interface in org.apache.flume.interceptor
-
Builder implementations MUST have a no-arg constructor
- InterceptorBuilderFactory - Class in org.apache.flume.interceptor
-
Factory used to register instances of Interceptors & their builders,
as well as to instantiate the builders.
- InterceptorBuilderFactory() - Constructor for class org.apache.flume.interceptor.InterceptorBuilderFactory
-
- InterceptorChain - Class in org.apache.flume.interceptor
-
Implementation of Interceptor that calls a list of other Interceptors
serially.
- InterceptorChain() - Constructor for class org.apache.flume.interceptor.InterceptorChain
-
- InterceptorType - Enum in org.apache.flume.interceptor
-
- InterfaceAudience - Class in org.apache.flume.annotations
-
Annotation to inform users of a package, class or method's intended audience.
- InterfaceAudience.LimitedPrivate - Annotation Type in org.apache.flume.annotations
-
Intended only for the project(s) specified in the annotation.
- InterfaceAudience.Private - Annotation Type in org.apache.flume.annotations
-
Intended for use only within Flume
- InterfaceAudience.Public - Annotation Type in org.apache.flume.annotations
-
Intended for use by any project or application.
- InterfaceStability - Class in org.apache.flume.annotations
-
Annotation to inform users of how much to rely on a particular package,
class or method not changing over time.
- InterfaceStability() - Constructor for class org.apache.flume.annotations.InterfaceStability
-
- InterfaceStability.Evolving - Annotation Type in org.apache.flume.annotations
-
Evolving, but can break compatibility at minor release (i.e.
- InterfaceStability.Stable - Annotation Type in org.apache.flume.annotations
-
Can evolve while retaining compatibility for minor release boundaries.;
can break compatibility only at major release (ie.
- InterfaceStability.Unstable - Annotation Type in org.apache.flume.annotations
-
No guarantee is provided as to reliability or stability across any
level of release granularity.
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
- IRCConnectionListener() - Constructor for class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
-
- IRCSink - Class in org.apache.flume.sink.irc
-
- IRCSink() - Constructor for class org.apache.flume.sink.irc.IRCSink
-
- IRCSink.IRCConnectionListener - Class in org.apache.flume.sink.irc
-
- isActive() - Method in class org.apache.flume.api.AbstractRpcClient
-
- isActive() - Method in class org.apache.flume.api.FailoverRpcClient
-
- isActive() - Method in class org.apache.flume.api.LoadBalancingRpcClient
-
- isActive() - Method in class org.apache.flume.api.NettyAvroRpcClient
-
- isActive() - Method in interface org.apache.flume.api.RpcClient
-
Returns true
if this object appears to be in a usable state, and
it returns false
if this object is permanently disabled.
- isActive() - Method in class org.apache.flume.api.ThriftRpcClient
-
- isAuthenticated() - Method in interface org.apache.flume.auth.FlumeAuthenticator
-
Returns true, if the underlying Authenticator was obtained by
successful kerberos authentication
- isComponentInErrorState(LifecycleAware) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
-
- isEmpty() - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
-
- isGanglia3() - Method in class org.apache.flume.instrumentation.GangliaServer
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
- isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
-
- isMatch(Event) - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
-
- isNotFoundConfigClass() - Method in class org.apache.flume.conf.ComponentConfiguration
-
- isOneway() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor.append
-
- isOneway() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor.close
-
- isOneway() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor.append
-
- isOneway() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor.close
-
- isOneway() - Method in class org.apache.flume.source.scribe.Scribe.AsyncProcessor.Log
-
- isOneway() - Method in class org.apache.flume.source.scribe.Scribe.Processor.Log
-
- isOneway() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor.append
-
- isOneway() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor.appendBatch
-
- isOneway() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Processor.append
-
- isOneway() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Processor.appendBatch
-
- isOpen() - Method in class org.apache.flume.channel.file.FileChannel
-
- isOpen() - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- isOpen() - Method in interface org.apache.flume.channel.file.instrumentation.FileChannelCounterMBean
-
- isOverflowDisabled() - Method in class org.apache.flume.channel.SpillableMemoryChannel
-
- isSet(ThriftFlumeEvent._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftFlumeEventServer.append_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftFlumeEventServer.close_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftFlumeEventServer.close_result._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LogEntry._Fields) - Method in class org.apache.flume.source.scribe.LogEntry
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Scribe.Log_args._Fields) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Scribe.Log_result._Fields) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftFlumeEvent._Fields) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftSourceProtocol.append_args._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftSourceProtocol.append_result._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftSourceProtocol.appendBatch_args._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftSourceProtocol.appendBatch_result._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSetBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
Returns true if field body is set (has been assigned a value) and false otherwise
- isSetBody() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
Returns true if field body is set (has been assigned a value) and false otherwise
- isSetCategory() - Method in class org.apache.flume.source.scribe.LogEntry
-
Returns true if field category is set (has been assigned a value) and false otherwise
- isSetEvent() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
Returns true if field event is set (has been assigned a value) and false otherwise
- isSetEvents() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
Returns true if field events is set (has been assigned a value) and false otherwise
- isSetEvt() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
Returns true if field evt is set (has been assigned a value) and false otherwise
- isSetFields() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
Returns true if field fields is set (has been assigned a value) and false otherwise
- isSetHeaders() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
Returns true if field headers is set (has been assigned a value) and false otherwise
- isSetHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
Returns true if field host is set (has been assigned a value) and false otherwise
- isSetMessage() - Method in class org.apache.flume.source.scribe.LogEntry
-
Returns true if field message is set (has been assigned a value) and false otherwise
- isSetMessages() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
Returns true if field messages is set (has been assigned a value) and false otherwise
- isSetNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
Returns true if field nanos is set (has been assigned a value) and false otherwise
- isSetPriority() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
Returns true if field priority is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isShouldBackOff() - Method in class org.apache.flume.util.OrderSelector
-
- isStarted() - Method in class org.apache.flume.source.BasicSourceSemantics
-
- isUnderReplicated() - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
-
Contract for subclasses: Call registerCurrentStream() on open,
unregisterCurrentStream() on close, and the base class takes care of the
rest.
- isUnderReplicated() - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
-
- isWindows() - Static method in class org.apache.flume.tools.PlatformDetect
-
Detects whether we are running under Microsoft Windows.
- SAVE_FAILURE_POLICY - Static variable in class org.apache.flume.sink.kite.DatasetSinkConstants
-
Write non-recoverable Flume events to a Kite dataset.
- SavePolicy - Class in org.apache.flume.sink.kite.policy
-
A failure policy that writes the raw Flume event to a Kite dataset.
- SavePolicy.Builder - Class in org.apache.flume.sink.kite.policy
-
- schemaExists() - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- schemaExists() - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
-
- schemaExists() - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
-
- SchemaHandler - Interface in org.apache.flume.channel.jdbc.impl
-
A handler for creating and validating database schema for use by
the JDBC channel implementation.
- SchemaHandlerFactory - Class in org.apache.flume.channel.jdbc.impl
-
A factory for SchemaHandlers.
- Scribe - Class in org.apache.flume.source.scribe
-
- Scribe() - Constructor for class org.apache.flume.source.scribe.Scribe
-
- Scribe.AsyncClient - Class in org.apache.flume.source.scribe
-
- Scribe.AsyncClient.Factory - Class in org.apache.flume.source.scribe
-
- Scribe.AsyncClient.Log_call - Class in org.apache.flume.source.scribe
-
- Scribe.AsyncIface - Interface in org.apache.flume.source.scribe
-
- Scribe.AsyncProcessor<I extends Scribe.AsyncIface> - Class in org.apache.flume.source.scribe
-
- Scribe.AsyncProcessor.Log<I extends Scribe.AsyncIface> - Class in org.apache.flume.source.scribe
-
- Scribe.Client - Class in org.apache.flume.source.scribe
-
- Scribe.Client.Factory - Class in org.apache.flume.source.scribe
-
- Scribe.Iface - Interface in org.apache.flume.source.scribe
-
- Scribe.Log_args - Class in org.apache.flume.source.scribe
-
- Scribe.Log_args._Fields - Enum in org.apache.flume.source.scribe
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Scribe.Log_result - Class in org.apache.flume.source.scribe
-
- Scribe.Log_result._Fields - Enum in org.apache.flume.source.scribe
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Scribe.Processor<I extends Scribe.Iface> - Class in org.apache.flume.source.scribe
-
- Scribe.Processor.Log<I extends Scribe.Iface> - Class in org.apache.flume.source.scribe
-
- SCRIBE_CATEGORY - Static variable in class org.apache.flume.source.scribe.ScribeSource
-
- ScribeSource - Class in org.apache.flume.source.scribe
-
Flume should adopt the Scribe entry LogEntry
from existing
Scribe system.
- ScribeSource() - Constructor for class org.apache.flume.source.scribe.ScribeSource
-
- SearchAndReplaceInterceptor - Class in org.apache.flume.interceptor
-
Interceptor that allows search-and-replace of event body strings using
regular expressions.
- SearchAndReplaceInterceptor.Builder - Class in org.apache.flume.interceptor
-
- SECOND - Static variable in class org.apache.flume.sink.hive.Config
-
- SecureRpcClientFactory - Class in org.apache.flume.api
-
Factory class to construct Flume RPCClient
implementations.
- SecureRpcClientFactory() - Constructor for class org.apache.flume.api.SecureRpcClientFactory
-
- SecureThriftRpcClient - Class in org.apache.flume.api
-
- SecureThriftRpcClient() - Constructor for class org.apache.flume.api.SecureThriftRpcClient
-
- SecureThriftRpcClient.UgiSaslClientTransport - Class in org.apache.flume.api
-
This transport wraps the Sasl transports to set up the right UGI context for open().
- SecurityException - Exception in org.apache.flume.auth
-
SecurityException thrown in the Flume security module
- SecurityException(String) - Constructor for exception org.apache.flume.auth.SecurityException
-
- SecurityException(String, Throwable) - Constructor for exception org.apache.flume.auth.SecurityException
-
- SecurityException(Throwable) - Constructor for exception org.apache.flume.auth.SecurityException
-
- seek(long) - Method in class org.apache.flume.serialization.ResettableFileInputStream
-
- seek(long) - Method in class org.apache.flume.serialization.ResettableInputStream
-
Seek to the specified byte position in the stream.
- seek(long) - Method in interface org.apache.flume.serialization.Seekable
-
- Seekable - Interface in org.apache.flume.serialization
-
- SELECTOR_NAME_RANDOM - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
-
- SELECTOR_NAME_RANDOM_BACKOFF - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
-
- SELECTOR_NAME_ROUND_ROBIN - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
-
- SELECTOR_NAME_ROUND_ROBIN_BACKOFF - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
-
- selectorConf - Variable in class org.apache.flume.conf.source.SourceConfiguration
-
- send_append(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
-
- send_append(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client
-
- send_appendBatch(List<ThriftFlumeEvent>) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client
-
- send_close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
-
- send_Log(List<LogEntry>) - Method in class org.apache.flume.source.scribe.Scribe.Client
-
- sendToGangliaNodes() - Method in class org.apache.flume.instrumentation.GangliaServer
-
- SEPERATOR - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
- SequenceFileSerializer - Interface in org.apache.flume.sink.hdfs
-
- SequenceFileSerializer.Builder - Interface in org.apache.flume.sink.hdfs
-
Knows how to construct this output formatter.
Note: Implementations MUST provide a public a no-arg constructor.
- SequenceFileSerializer.Record - Class in org.apache.flume.sink.hdfs
-
A key-value pair making up a record in an HDFS SequenceFile
- SequenceFileSerializerFactory - Class in org.apache.flume.sink.hdfs
-
- SequenceFileSerializerFactory() - Constructor for class org.apache.flume.sink.hdfs.SequenceFileSerializerFactory
-
- SequenceFileSerializerType - Enum in org.apache.flume.sink.hdfs
-
- SequenceGeneratorSource - Class in org.apache.flume.source
-
- SequenceGeneratorSource() - Constructor for class org.apache.flume.source.SequenceGeneratorSource
-
- SequentialReader(File, KeyProvider, boolean) - Constructor for class org.apache.flume.channel.file.LogFileV3.SequentialReader
-
- Serialization - Class in org.apache.flume.channel.file
-
- serialize(String) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorMillisSerializer
-
- serialize(String) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorPassThroughSerializer
-
- serialize(String) - Method in interface org.apache.flume.interceptor.RegexExtractorInterceptorSerializer
-
- serialize(Event) - Method in class org.apache.flume.sink.hdfs.HDFSTextSerializer
-
- serialize(Event) - Method in class org.apache.flume.sink.hdfs.HDFSWritableSerializer
-
- serialize(Event) - Method in interface org.apache.flume.sink.hdfs.SequenceFileSerializer
-
Format the given event into zero, one or more SequenceFile records
- SERIALIZER - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
-
The fully qualified class name of the serializer the sink should use.
- serializer - Variable in class org.apache.flume.sink.elasticsearch.EventSerializerIndexRequestBuilderFactory
-
- SERIALIZER - Static variable in class org.apache.flume.sink.hive.Config
-
- SERIALIZER_DELIMITER - Static variable in class org.apache.flume.sink.hive.HiveDelimitedTextSerializer
-
- SERIALIZER_FIELDNAMES - Static variable in class org.apache.flume.sink.hive.HiveDelimitedTextSerializer
-
- SERIALIZER_PREFIX - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
-
Configuration to pass to the serializer.
- SERIALIZER_SERDE_SEPARATOR - Static variable in class org.apache.flume.sink.hive.HiveDelimitedTextSerializer
-
- set(String, Long) - Method in class org.apache.flume.CounterGroup
-
- set(String, long) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
-
Sets the value for this key to the given value
- SET_TOPIC_HEADER - Static variable in class org.apache.flume.source.kafka.KafkaSourceConstants
-
- setActiveLogs(int, ProtosFactory.ActiveLog) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- setActiveLogs(int, ProtosFactory.ActiveLog.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
repeated .ActiveLog activeLogs = 5;
- setAvroReflectionEnabled(boolean) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
- setAvroSchemaUrl(String) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
- setBackOff(boolean) - Method in class org.apache.flume.source.SpoolDirectorySource
-
The class always backs off, this exists only so that we can test without
taking a really long time.
- setBackupCheckpointPosition(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional sfixed64 backupCheckpointPosition = 6;
- setBackupCheckpointWriteOrderID(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional sfixed64 backupCheckpointWriteOrderID = 7;
- setBaseDirectory(File) - Method in class org.apache.flume.formatter.output.DefaultPathManager
-
- setBaseDirectory(File) - Method in interface org.apache.flume.formatter.output.PathManager
-
- setBasePayload(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
-
- setBody(byte[]) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setBody(ByteBuffer) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setBody(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
required bytes body = 2;
- setBody(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
-
- setBody(byte[]) - Method in class org.apache.flume.event.JSONEvent
-
- setBody(byte[]) - Method in interface org.apache.flume.Event
-
Sets the raw byte array of the data contained in this event.
- setBody(byte[]) - Method in class org.apache.flume.event.SimpleEvent
-
- setBody(byte[]) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- setBody(ByteBuffer) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- setBodyIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setBodyIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- setCategory(String) - Method in class org.apache.flume.source.scribe.LogEntry
-
- setCategoryIsSet(boolean) - Method in class org.apache.flume.source.scribe.LogEntry
-
- setChannel(String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
-
- setChannel(Channel) - Method in class org.apache.flume.sink.AbstractSink
-
- setChannel(Channel) - Method in interface org.apache.flume.Sink
-
Sets the channel the sink will consume from
- setChannelCapacity(long) - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- setChannelProcessor(ChannelProcessor) - Method in class org.apache.flume.source.AbstractSource
-
- setChannelProcessor(ChannelProcessor) - Method in class org.apache.flume.source.BasicSourceSemantics
-
- setChannelProcessor(ChannelProcessor) - Method in interface org.apache.flume.Source
-
Specifies which channel processor will handle this source's events.
- setChannels(List<Channel>) - Method in class org.apache.flume.channel.AbstractChannelSelector
-
- setChannels(List<Channel>) - Method in interface org.apache.flume.ChannelSelector
-
- setChannels(Set<String>) - Method in class org.apache.flume.conf.channel.ChannelSelectorConfiguration
-
- setChannelSize(long) - Method in class org.apache.flume.instrumentation.ChannelCounter
-
- setCharset(String) - Method in class org.apache.flume.event.JSONEvent
-
- setCheckpointPosition(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed64 checkpointPosition = 3;
- setCheckpointWriteOrderID(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed64 checkpointWriteOrderID = 4;
- setChecksum(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
optional sfixed64 checksum = 2;
- setCipherProvider(String) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string cipherProvider = 1;
- setCipherProviderBytes(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string cipherProvider = 1;
- setClock(Clock) - Static method in class org.apache.flume.formatter.output.BucketPath
-
- setConfigured() - Method in class org.apache.flume.conf.ComponentConfiguration
-
- setCount(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
required sfixed32 count = 2;
- setCounters(HashMap<String, AtomicLong>) - Method in class org.apache.flume.CounterGroup
-
- setCurrentFile(TailFile) - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader
-
- setDesiredState(LifecycleAware, LifecycleState) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
-
- setDirectory(File) - Method in class org.apache.flume.sink.RollingFileSink
-
- setEncryption(ProtosFactory.LogFileEncryption) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional .LogFileEncryption encryption = 5;
- setEncryption(ProtosFactory.LogFileEncryption.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
optional .LogFileEncryption encryption = 5;
- setEvent(ProtosFactory.FlumeEvent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
required .FlumeEvent event = 1;
- setEvent(ProtosFactory.FlumeEvent.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
-
required .FlumeEvent event = 1;
- setEvent(Event) - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
-
- setEvent(Event) - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
-
- setEvent(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- setEventId(long) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
-
- setEventId(long) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
-
- setEventIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- setEvents(List<ThriftFlumeEvent>) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- setEventsIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- setEventSize(int) - Method in class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
-
Deprecated.
- setEventSize(Integer) - Method in class org.apache.flume.source.SyslogUtils
-
- setEvt(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- setEvtIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- setFields(Map<String, ByteBuffer>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setFieldsIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setFieldValue(ThriftFlumeEvent._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setFieldValue(ThriftFlumeEventServer.append_args._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- setFieldValue(ThriftFlumeEventServer.close_args._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
-
- setFieldValue(ThriftFlumeEventServer.close_result._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
-
- setFieldValue(LogEntry._Fields, Object) - Method in class org.apache.flume.source.scribe.LogEntry
-
- setFieldValue(Scribe.Log_args._Fields, Object) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- setFieldValue(Scribe.Log_result._Fields, Object) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
- setFieldValue(ThriftFlumeEvent._Fields, Object) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- setFieldValue(ThriftSourceProtocol.append_args._Fields, Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- setFieldValue(ThriftSourceProtocol.append_result._Fields, Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- setFieldValue(ThriftSourceProtocol.appendBatch_args._Fields, Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- setFieldValue(ThriftSourceProtocol.appendBatch_result._Fields, Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- setFileID(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
required sfixed32 fileID = 1;
- setFormater(Map<String, String>) - Method in class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
-
Deprecated.
- setFormater(Map<String, String>) - Method in class org.apache.flume.source.SyslogUDPSource.syslogHandler
-
- setHeader(long, String, String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
-
- setHeaderNameSpill(long, String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
-
- setHeaders(int, ProtosFactory.FlumeEventHeader) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- setHeaders(int, ProtosFactory.FlumeEventHeader.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
-
repeated .FlumeEventHeader headers = 1;
- setHeaders(Map<String, String>) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
-
- setHeaders(Map<String, String>) - Method in class org.apache.flume.event.JSONEvent
-
- setHeaders(Map<String, String>) - Method in interface org.apache.flume.Event
-
Set the event headers
- setHeaders(Map<String, String>) - Method in class org.apache.flume.event.SimpleEvent
-
- setHeaders(Map<String, String>) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- setHeadersIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- setHeaderValueSpill(long, String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
-
- setHost(String) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setHostIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setHostname(String) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
Set the first flume hop hostname.
- setHosts(List<HostInfo>) - Method in interface org.apache.flume.api.LoadBalancingRpcClient.HostSelector
-
- setHosts(String) - Method in class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
-
- setId(long) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
-
- setInterceptors(List<Interceptor>) - Method in class org.apache.flume.interceptor.InterceptorChain
-
- setIsGanglia3(boolean) - Method in class org.apache.flume.instrumentation.GangliaServer
-
- setKeepFields(Set<String>) - Method in class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
-
Deprecated.
- setKeepFields(Set<String>) - Method in class org.apache.flume.source.SyslogUDPSource.syslogHandler
-
- setKeepFields(Set<String>) - Method in class org.apache.flume.source.SyslogUtils
-
- setKey(Key) - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor.Builder
-
- setKey(Key) - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor.Builder
-
- setKey(String) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
required string key = 1;
- setKeyAlias(String) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string keyAlias = 2;
- setKeyAliasBytes(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
required string keyAlias = 2;
- setKeyBytes(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
required string key = 1;
- setLastCheckpointPosition(long) - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
-
- setLastCheckpointWriteOrderID(long) - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
-
- setLastUpdated(long) - Method in class org.apache.flume.source.taildir.TailFile
-
- setLifecycleState(LifecycleState) - Method in class org.apache.flume.source.BasicSourceSemantics
-
- setLineReadPos(long) - Method in class org.apache.flume.source.taildir.TailFile
-
- setLogFileID(int) - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
-
- setLogFileID(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
-
required sfixed32 logFileID = 1;
- setLogFileID(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed32 logFileID = 2;
- setMaxBackoff(String) - Method in class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
-
- setMaxTimeOut(long) - Method in class org.apache.flume.util.OrderSelector
-
- setMessage(String) - Method in class org.apache.flume.source.scribe.LogEntry
-
- setMessageIsSet(boolean) - Method in class org.apache.flume.source.scribe.LogEntry
-
- setMessages(List<LogEntry>) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- setMessagesIsSet(boolean) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- setName(String) - Method in class org.apache.flume.channel.AbstractChannel
-
- setName(String) - Method in class org.apache.flume.channel.AbstractChannelSelector
-
- setName(String) - Method in class org.apache.flume.channel.file.FileChannel
-
- setName(String) - Method in class org.apache.flume.CounterGroup
-
- setName(String) - Method in interface org.apache.flume.NamedComponent
-
- setName(String) - Method in class org.apache.flume.sink.AbstractSink
-
- setName(String) - Method in class org.apache.flume.source.AbstractSource
-
- setName(String) - Method in class org.apache.flume.source.BasicSourceSemantics
-
- setNanos(long) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setNanosIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setNeedTail(boolean) - Method in class org.apache.flume.source.taildir.TailFile
-
- setNotFoundConfigClass() - Method in class org.apache.flume.conf.ComponentConfiguration
-
- setObjects(List<T>) - Method in class org.apache.flume.util.OrderSelector
-
Set the list of objects which this class should return in order.
- setOffset(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
-
required sfixed32 offset = 2;
- setOpen(boolean) - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- setOpenConnectionCount(long) - Method in class org.apache.flume.instrumentation.SourceCounter
-
- setParameters(byte[]) - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor.Builder
-
- setParameters(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
-
optional bytes parameters = 3;
- setPollFrequency(int) - Method in class org.apache.flume.instrumentation.GangliaServer
-
- setPort(int) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
Set the port on the hostname to connect to.
- setPos(long) - Method in class org.apache.flume.source.taildir.TailFile
-
- setPreviousCheckpointPosition(long) - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
-
- setPreviousCheckpointWriteOrderID(long) - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
-
- setPriority(Priority) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setPriorityIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setProcessorContext(Context) - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
-
- setQueueHead(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 queueHead = 4;
- setQueueSize(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 queueSize = 3;
- setRollInterval(long) - Method in class org.apache.flume.sink.RollingFileSink
-
- setSeed(long) - Static method in class org.apache.flume.channel.file.TransactionIDOracle
-
- setSeed(long) - Static method in class org.apache.flume.channel.file.WriteOrderOracle
-
- setSelector(String) - Method in class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
-
- setSink(SinkProcessor) - Method in class org.apache.flume.SinkRunner
-
- setSinkProcessorConfiguration(SinkProcessorConfiguration) - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
-
- setSinks(List<String>) - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
-
- setSinks(Set<String>) - Method in class org.apache.flume.conf.sink.SinkProcessorConfiguration
-
- setSinks(List<Sink>) - Method in class org.apache.flume.sink.AbstractSinkProcessor
-
- setSinks(List<Sink>) - Method in class org.apache.flume.sink.AbstractSinkSelector
-
- setSinks(List<Sink>) - Method in class org.apache.flume.sink.DefaultSinkProcessor
-
- setSinks(List<Sink>) - Method in class org.apache.flume.sink.FailoverSinkProcessor
-
- setSinks(List<Sink>) - Method in interface org.apache.flume.sink.LoadBalancingSinkProcessor.SinkSelector
-
- setSinks(List<Sink>) - Method in interface org.apache.flume.SinkProcessor
-
Set all sinks to work with.
- setSource(Source) - Method in class org.apache.flume.SourceRunner
-
- setSpillPayload(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
-
- setSuccess(ResultCode) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
- setSuccess(Status) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- setSuccess(Status) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- setTimeout(long) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
- setTimestamp(long) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setTimestampIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- setTransactionID(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed64 transactionID = 2;
- setType(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
-
required sfixed32 type = 1;
- setType(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed32 type = 1;
- setType(String) - Method in class org.apache.flume.conf.ComponentConfiguration
-
- setUnhealthy(int) - Method in class org.apache.flume.channel.file.instrumentation.FileChannelCounter
-
- setUnsafeMode(boolean) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
-
- setValue(String) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
optional string value = 2;
- setValueBytes(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
-
optional string value = 2;
- setVersion(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed32 version = 1;
- setVersion(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
-
required sfixed32 version = 1;
- setWriteOrderID(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
-
required sfixed64 writeOrderID = 2;
- setWriteOrderID(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
-
required sfixed64 writeOrderID = 3;
- sharedInstance() - Static method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
-
- SimpleAsyncHbaseEventSerializer - Class in org.apache.flume.sink.hbase
-
A simple serializer to be used with the AsyncHBaseSink
that returns puts from an event, by writing the event
body into it.
- SimpleAsyncHbaseEventSerializer() - Constructor for class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
-
- simpleDateFormatCache - Static variable in class org.apache.flume.formatter.output.BucketPath
-
- SimpleEvent - Class in org.apache.flume.event
-
- SimpleEvent() - Constructor for class org.apache.flume.event.SimpleEvent
-
- SimpleHbaseEventSerializer - Class in org.apache.flume.sink.hbase
-
A simple serializer that returns puts from an event, by writing the event
body into it.
- SimpleHbaseEventSerializer() - Constructor for class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
-
- SimpleHbaseEventSerializer.KeyType - Enum in org.apache.flume.sink.hbase
-
- SimpleIndexNameBuilder - Class in org.apache.flume.sink.elasticsearch
-
- SimpleIndexNameBuilder() - Constructor for class org.apache.flume.sink.elasticsearch.SimpleIndexNameBuilder
-
- SimpleMaterializedConfiguration - Class in org.apache.flume.node
-
- SimpleMaterializedConfiguration() - Constructor for class org.apache.flume.node.SimpleMaterializedConfiguration
-
- SimpleRowKeyGenerator - Class in org.apache.flume.sink.hbase
-
Utility class for users to generate their own keys.
- SimpleRowKeyGenerator() - Constructor for class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
-
- SimpleTextLineEventReader - Class in org.apache.flume.client.avro
-
- SimpleTextLineEventReader(Reader) - Constructor for class org.apache.flume.client.avro.SimpleTextLineEventReader
-
- Sink - Interface in org.apache.flume
-
A sink is connected to a Channel and consumes its contents,
sending them to a configured destination that may vary according to
the sink type.
- Sink.Status - Enum in org.apache.flume
-
- SINK_PROCESSOR - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Prefix for sink processor properties
- SINK_PROCESSOR_PREFIX - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Prefix for passing configuration parameters to the sink processor
- SINK_PROCESSOR_TYPE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Sink processor type, choices are `default', `failover' or `load_balance'
- SINK_PROCESSOR_TYPE_DEFAULT - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Default sink processors which may be used when there is only a single sink.
- SINK_PROCESSOR_TYPE_FAILOVER - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Failover sink processor.
- SINK_PROCESSOR_TYPE_LOAD_BALANCE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Load balancing sink processor.
- SINK_TYPE_AVRO - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Avro sink which can send events to a downstream avro source.
- SinkConfiguration - Class in org.apache.flume.conf.sink
-
- SinkConfiguration(String) - Constructor for class org.apache.flume.conf.sink.SinkConfiguration
-
- SinkConfiguration.SinkConfigurationType - Enum in org.apache.flume.conf.sink
-
- SinkCounter - Class in org.apache.flume.instrumentation
-
- SinkCounter(String) - Constructor for class org.apache.flume.instrumentation.SinkCounter
-
- SinkCounter(String, String[]) - Constructor for class org.apache.flume.instrumentation.SinkCounter
-
- SinkCounterMBean - Interface in org.apache.flume.instrumentation
-
This interface represents a sink counter mbean.
- SinkFactory - Interface in org.apache.flume
-
- SinkGroup - Class in org.apache.flume.sink
-
Configuration concept for handling multiple sinks working together.
- SinkGroup(List<Sink>) - Constructor for class org.apache.flume.sink.SinkGroup
-
- SinkGroupConfiguration - Class in org.apache.flume.conf.sink
-
- SinkGroupConfiguration(String) - Constructor for class org.apache.flume.conf.sink.SinkGroupConfiguration
-
- SinkProcessor - Interface in org.apache.flume
-
Interface for a device that allows abstraction of the behavior of multiple
sinks, always assigned to a SinkRunner
- SinkProcessorConfiguration - Class in org.apache.flume.conf.sink
-
- SinkProcessorConfiguration(String) - Constructor for class org.apache.flume.conf.sink.SinkProcessorConfiguration
-
- SinkProcessorConfiguration.SinkProcessorConfigurationType - Enum in org.apache.flume.conf.sink
-
- SinkProcessorCounter - Class in org.apache.flume.instrumentation
-
- SinkProcessorCounter(String) - Constructor for class org.apache.flume.instrumentation.SinkProcessorCounter
-
- SinkProcessorFactory - Class in org.apache.flume.sink
-
- SinkProcessorFactory() - Constructor for class org.apache.flume.sink.SinkProcessorFactory
-
- SinkProcessorType - Enum in org.apache.flume.conf.sink
-
- SinkRunner - Class in org.apache.flume
-
A driver for
sinks that polls them, attempting to
process events if any are available in the
Channel
.
- SinkRunner() - Constructor for class org.apache.flume.SinkRunner
-
- SinkRunner(SinkProcessor) - Constructor for class org.apache.flume.SinkRunner
-
- SinkRunner.PollingRunner - Class in org.apache.flume
-
- SINKS - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Space delimited list of sink names: e.g.
- sinks - Variable in class org.apache.flume.conf.sink.SinkProcessorConfiguration
-
- SINKS_PREFIX - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
- SinkType - Enum in org.apache.flume.conf.sink
-
Enumeration of built in sink types available in the system.
- size() - Method in class org.apache.flume.sink.elasticsearch.client.RoundRobinList
-
- SKIP_TO_END - Static variable in class org.apache.flume.source.taildir.TaildirSourceConfigurationConstants
-
Whether to skip the position to EOF in the case of files not written on the position file.
- skipRecord(RandomAccessFile, int) - Static method in class org.apache.flume.channel.file.LogFile
-
- skipToEnd(boolean) - Method in class org.apache.flume.source.taildir.ReliableTaildirEventReader.Builder
-
- SOURCE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Prefix for source properties
- Source - Interface in org.apache.flume
-
A source generates and calls methods on the
configured
ChannelProcessor
to persist those events into the
configured
channels.
- SOURCE_PREFIX - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Prefix for passing configuration parameters to the source
- SOURCE_TYPE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Source type, choices are `embedded'
- SOURCE_TYPE_EMBEDDED - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
-
Embedded source which provides simple in-memory transfer to channel.
- SourceConfiguration - Class in org.apache.flume.conf.source
-
- SourceConfiguration(String) - Constructor for class org.apache.flume.conf.source.SourceConfiguration
-
- SourceConfiguration.SourceConfigurationType - Enum in org.apache.flume.conf.source
-
- SourceCounter - Class in org.apache.flume.instrumentation
-
- SourceCounter(String) - Constructor for class org.apache.flume.instrumentation.SourceCounter
-
- SourceCounter(String, String[]) - Constructor for class org.apache.flume.instrumentation.SourceCounter
-
- SourceCounterMBean - Interface in org.apache.flume.instrumentation
-
This interface represents a source counter mbean.
- SourceFactory - Interface in org.apache.flume
-
- SourceRunner - Class in org.apache.flume
-
A source runner controls how a source is driven.
- SourceRunner() - Constructor for class org.apache.flume.SourceRunner
-
- SourceType - Enum in org.apache.flume.conf.source
-
Enumeration of built in source types available in the system.
- SpecificOrderIterator<T> - Class in org.apache.flume.util
-
A utility class that iterates over the given ordered list of items via
the specified order array.
- SpecificOrderIterator(int[], List<T>) - Constructor for class org.apache.flume.util.SpecificOrderIterator
-
- SpillableMemoryChannel - Class in org.apache.flume.channel
-
SpillableMemoryChannel will use main memory for buffering events until it has reached capacity.
- SpillableMemoryChannel() - Constructor for class org.apache.flume.channel.SpillableMemoryChannel
-
- SpillableMemoryChannel.DrainOrderQueue - Class in org.apache.flume.channel
-
- SpillableString(String, int) - Constructor for class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
-
- splitKerberosName(String) - Static method in class org.apache.flume.auth.FlumeAuthenticationUtil
-
Resolves the principal using Hadoop common's SecurityUtil and splits
the kerberos principal into three parts user name, host and kerberos realm
- SPOOL_DIRECTORY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
-
Directory where files are deposited.
- spoolDirectory(File) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
-
- SpoolDirectorySource - Class in org.apache.flume.source
-
- SpoolDirectorySource() - Constructor for class org.apache.flume.source.SpoolDirectorySource
-
- SpoolDirectorySourceConfigurationConstants - Class in org.apache.flume.source
-
- SpoolDirectorySourceConfigurationConstants() - Constructor for class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
-
- SpoolDirectorySourceConfigurationConstants.ConsumeOrder - Enum in org.apache.flume.source
-
Consume order.
- SPOOLED_FILE_SUFFIX - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
-
Suffix appended to files when they are finished being sent.
- SSL_ENABLED - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
-
- SSL_KEYSTORE - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
-
- SSL_KEYSTORE_PASSWORD - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
-
- start(I, ThriftFlumeEventServer.append_args, AsyncMethodCallback<Void>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor.append
-
- start(I, ThriftFlumeEventServer.close_args, AsyncMethodCallback<Void>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncProcessor.close
-
- start() - Method in class org.apache.flume.agent.embedded.EmbeddedAgent
-
Started the agent.
- start() - Method in class org.apache.flume.channel.AbstractChannel
-
- start() - Method in class org.apache.flume.channel.file.FileChannel
-
- start() - Method in class org.apache.flume.channel.kafka.KafkaChannel
-
- start() - Method in class org.apache.flume.channel.MemoryChannel
-
- start() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
-
- start() - Method in class org.apache.flume.channel.SpillableMemoryChannel
-
- start() - Method in class org.apache.flume.instrumentation.GangliaServer
-
Start this server, causing it to poll JMX at the configured frequency.
- start() - Method in class org.apache.flume.instrumentation.http.HTTPMetricsServer
-
- start() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
-
Starts the component
Initializes the values for the stop time as well as all the keys in the
internal map to zero and sets the start time to the current time in
milliseconds since midnight January 1, 1970 UTC
- start() - Method in interface org.apache.flume.instrumentation.MonitorService
-
- start() - Method in interface org.apache.flume.lifecycle.LifecycleAware
-
Starts a service or component.
- start() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
-
- start() - Method in class org.apache.flume.node.Application
-
- start() - Method in class org.apache.flume.node.PollingPropertiesFileConfigurationProvider
-
- start() - Method in class org.apache.flume.node.PollingZooKeeperConfigurationProvider
-
- start() - Method in class org.apache.flume.sink.AbstractRpcSink
-
The start() of RpcSink is more of an optimization that allows connection
to be created before the process() loop is started.
- start() - Method in class org.apache.flume.sink.AbstractSink
-
- start() - Method in class org.apache.flume.sink.AbstractSinkProcessor
-
- start() - Method in class org.apache.flume.sink.AbstractSinkSelector
-
- start() - Method in class org.apache.flume.sink.DefaultSinkProcessor
-
- start() - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchSink
-
- start() - Method in class org.apache.flume.sink.hbase.AsyncHBaseSink
-
- start() - Method in class org.apache.flume.sink.hbase.HBaseSink
-
- start() - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
-
- start() - Method in class org.apache.flume.sink.hive.HiveSink
-
- start() - Method in class org.apache.flume.sink.http.HttpSink
-
- start() - Method in class org.apache.flume.sink.irc.IRCSink
-
- start() - Method in class org.apache.flume.sink.kafka.KafkaSink
-
- start() - Method in class org.apache.flume.sink.kite.DatasetSink
-
- start() - Method in class org.apache.flume.sink.LoadBalancingSinkProcessor
-
- start() - Method in class org.apache.flume.sink.NullSink
-
- start() - Method in class org.apache.flume.sink.RollingFileSink
-
- start() - Method in class org.apache.flume.sink.solr.morphline.MorphlineSink
-
- start() - Method in class org.apache.flume.SinkRunner
-
- start() - Method in class org.apache.flume.source.AbstractSource
-
- start() - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
-
- start() - Method in class org.apache.flume.source.AvroSource
-
- start() - Method in class org.apache.flume.source.BasicSourceSemantics
-
- start() - Method in class org.apache.flume.source.EventDrivenSourceRunner
-
- start() - Method in class org.apache.flume.source.ExecSource
-
- start() - Method in class org.apache.flume.source.http.HTTPSource
-
- start() - Method in class org.apache.flume.source.MultiportSyslogTCPSource
-
- start() - Method in class org.apache.flume.source.NetcatSource
-
- start() - Method in class org.apache.flume.source.NetcatUdpSource
-
- start() - Method in class org.apache.flume.source.PollableSourceRunner
-
- start(I, Scribe.Log_args, AsyncMethodCallback<ResultCode>) - Method in class org.apache.flume.source.scribe.Scribe.AsyncProcessor.Log
-
- start() - Method in class org.apache.flume.source.scribe.ScribeSource
-
- start() - Method in class org.apache.flume.source.SpoolDirectorySource
-
- start() - Method in class org.apache.flume.source.SyslogTcpSource
-
Deprecated.
- start() - Method in class org.apache.flume.source.SyslogUDPSource
-
- start() - Method in class org.apache.flume.source.taildir.TaildirSource
-
- start() - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource
-
- start() - Method in class org.apache.flume.source.ThriftSource
-
- start() - Method in class org.apache.flume.source.twitter.TwitterSource
-
- start(I, ThriftSourceProtocol.append_args, AsyncMethodCallback<Status>) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor.append
-
- start(I, ThriftSourceProtocol.appendBatch_args, AsyncMethodCallback<Status>) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncProcessor.appendBatch
-
- START_OR_ERROR - Static variable in enum org.apache.flume.lifecycle.LifecycleState
-
- startCredentialRefresher() - Method in interface org.apache.flume.auth.FlumeAuthenticator
-
For Authenticators backed by credentials, this method refreshes the
credentials periodically
- STATIC_PARTITION_CONF - Static variable in class org.apache.flume.channel.kafka.KafkaChannelConfiguration
-
- STATIC_PARTITION_CONF - Static variable in class org.apache.flume.sink.kafka.KafkaSinkConstants
-
- STATIC_SCHEMA_URL - Static variable in class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
-
Avro static Schema URL
- StaticInterceptor - Class in org.apache.flume.interceptor
-
Interceptor class that appends a static, pre-configured header to all events.
- StaticInterceptor.Builder - Class in org.apache.flume.interceptor
-
Builder which builds new instance of the StaticInterceptor.
- StaticInterceptor.Constants - Class in org.apache.flume.interceptor
-
- StaticZooKeeperConfigurationProvider - Class in org.apache.flume.node
-
- StaticZooKeeperConfigurationProvider(String, String, String) - Constructor for class org.apache.flume.node.StaticZooKeeperConfigurationProvider
-
- Status() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.Status
-
- Status - Enum in org.apache.flume.thrift
-
- STMT_DELETE_EVENT_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_DELETE_EVENT_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_DELETE_HEADER_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_DELETE_HEADER_NAME_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_DELETE_HEADER_VALUE_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_FETCH_HEADER_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_FETCH_HEADER_NAME_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_FETCH_HEADER_VALUE_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_FETCH_PAYLOAD_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_FETCH_PAYLOAD_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_INSERT_EVENT_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_INSERT_EVENT_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_INSERT_HEADER_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_INSERT_HEADER_NAME_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- STMT_INSERT_HEADER_VALUE_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- stop() - Method in class org.apache.flume.agent.embedded.EmbeddedAgent
-
Stops the agent.
- stop() - Method in class org.apache.flume.channel.AbstractChannel
-
- stop() - Method in class org.apache.flume.channel.file.FileChannel
-
- stop() - Method in class org.apache.flume.channel.jdbc.JdbcChannel
-
- stop() - Method in class org.apache.flume.channel.kafka.KafkaChannel
-
- stop() - Method in class org.apache.flume.channel.MemoryChannel
-
- stop() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
-
- stop() - Method in class org.apache.flume.channel.SpillableMemoryChannel
-
- stop() - Method in class org.apache.flume.instrumentation.GangliaServer
-
Stop this server.
- stop() - Method in class org.apache.flume.instrumentation.http.HTTPMetricsServer
-
- stop() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
-
Shuts Down the Component
Used to indicate that the component is shutting down.
- stop() - Method in interface org.apache.flume.instrumentation.MonitorService
-
- stop() - Method in interface org.apache.flume.lifecycle.LifecycleAware
-
Stops a service or component.
- stop() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
-
- stop() - Method in class org.apache.flume.node.Application
-
- stop() - Method in class org.apache.flume.node.PollingPropertiesFileConfigurationProvider
-
- stop() - Method in class org.apache.flume.node.PollingZooKeeperConfigurationProvider
-
- stop() - Method in class org.apache.flume.sink.AbstractRpcSink
-
- stop() - Method in class org.apache.flume.sink.AbstractSink
-
- stop() - Method in class org.apache.flume.sink.AbstractSinkProcessor
-
- stop() - Method in class org.apache.flume.sink.AbstractSinkSelector
-
- stop() - Method in class org.apache.flume.sink.DefaultSinkProcessor
-
- stop() - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchSink
-
- stop() - Method in class org.apache.flume.sink.hbase.AsyncHBaseSink
-
- stop() - Method in class org.apache.flume.sink.hbase.HBaseSink
-
- stop() - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
-
- stop() - Method in class org.apache.flume.sink.hive.HiveSink
-
- stop() - Method in class org.apache.flume.sink.http.HttpSink
-
- stop() - Method in class org.apache.flume.sink.irc.IRCSink
-
- stop() - Method in class org.apache.flume.sink.kafka.KafkaSink
-
- stop() - Method in class org.apache.flume.sink.kite.DatasetSink
-
- stop() - Method in class org.apache.flume.sink.LoadBalancingSinkProcessor
-
- stop() - Method in class org.apache.flume.sink.NullSink
-
- stop() - Method in class org.apache.flume.sink.RollingFileSink
-
- stop() - Method in interface org.apache.flume.sink.solr.morphline.MorphlineHandler
-
Releases allocated resources
- stop() - Method in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
-
- stop() - Method in class org.apache.flume.sink.solr.morphline.MorphlineSink
-
- stop() - Method in class org.apache.flume.SinkRunner
-
- stop() - Method in class org.apache.flume.source.AbstractSource
-
- stop() - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
-
- stop() - Method in class org.apache.flume.source.AvroSource
-
- stop() - Method in class org.apache.flume.source.BasicSourceSemantics
-
- stop() - Method in class org.apache.flume.source.EventDrivenSourceRunner
-
- stop() - Method in class org.apache.flume.source.ExecSource
-
- stop() - Method in class org.apache.flume.source.http.HTTPSource
-
- stop() - Method in class org.apache.flume.source.MultiportSyslogTCPSource
-
- stop() - Method in class org.apache.flume.source.NetcatSource
-
- stop() - Method in class org.apache.flume.source.NetcatUdpSource
-
- stop() - Method in class org.apache.flume.source.PollableSourceRunner
-
- stop() - Method in class org.apache.flume.source.scribe.ScribeSource
-
- stop() - Method in class org.apache.flume.source.SpoolDirectorySource
-
- stop() - Method in class org.apache.flume.source.SyslogTcpSource
-
Deprecated.
- stop() - Method in class org.apache.flume.source.SyslogUDPSource
-
- stop() - Method in class org.apache.flume.source.taildir.TaildirSource
-
- stop() - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource
-
- stop() - Method in class org.apache.flume.source.ThriftSource
-
- stop() - Method in class org.apache.flume.source.twitter.TwitterSource
-
- STOP_OR_ERROR - Static variable in enum org.apache.flume.lifecycle.LifecycleState
-
- stopAll(List<LifecycleAware>) - Static method in class org.apache.flume.lifecycle.LifecycleController
-
- storeEvent(PersistableEvent, Connection) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- storeEvent(PersistableEvent, Connection) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
-
- storeEvent(PersistableEvent, Connection) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
-
Inserts the given persistent event into the database.
- storePosition(long) - Method in class org.apache.flume.serialization.DurablePositionTracker
-
- storePosition(long) - Method in interface org.apache.flume.serialization.PositionTracker
-
- StressSource - Class in org.apache.flume.source
-
StressSource is an internal load-generating source implementation
which is very useful for stress tests.
- StressSource() - Constructor for class org.apache.flume.source.StressSource
-
- subscribe(KafkaConsumer<?, ?>, SourceRebalanceListener) - Method in class org.apache.flume.source.kafka.KafkaSource.Subscriber
-
- Subscriber() - Constructor for class org.apache.flume.source.kafka.KafkaSource.Subscriber
-
- success - Variable in class org.apache.flume.source.scribe.Scribe.Log_result
-
- success - Variable in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- success - Variable in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- supervise(LifecycleAware, LifecycleSupervisor.SupervisorPolicy, LifecycleState) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
-
- supervisoree - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
-
- SupervisorPolicy() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.SupervisorPolicy
-
- supportsReopen() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
-
- supportsReopen() - Method in class org.apache.flume.serialization.BodyTextEventSerializer
-
- supportsReopen() - Method in interface org.apache.flume.serialization.EventSerializer
-
Specify whether this output format supports reopening files for append.
- supportsReopen() - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer
-
- supportsReopen() - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
-
- sync() - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
-
- sync() - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
-
- sync() - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
-
- sync() - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
-
- sync() - Method in interface org.apache.flume.sink.kite.policy.FailurePolicy
-
Ensure any handled events are on stable storage.
- sync() - Method in class org.apache.flume.sink.kite.policy.RetryPolicy
-
- sync() - Method in class org.apache.flume.sink.kite.policy.SavePolicy
-
- SYNC_INTERVAL_BYTES - Static variable in class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
-
Avro sync interval, in approximate bytes
- SYSLOG_BODY_POS - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_FACILITY - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_HOSTNAME_POS - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_MSG_RFC3164_0 - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_MSG_RFC5424_0 - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_PRIORITY - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_PRIORITY_POS - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_SEVERITY - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_TIMESTAMP_FORMAT_RFC3164_1 - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_TIMESTAMP_FORMAT_RFC5424_1 - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_TIMESTAMP_FORMAT_RFC5424_2 - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_TIMESTAMP_FORMAT_RFC5424_3 - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_TIMESTAMP_FORMAT_RFC5424_4 - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_TIMESTAMP_POS - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_VERSION - Static variable in class org.apache.flume.source.SyslogUtils
-
- SYSLOG_VERSION_POS - Static variable in class org.apache.flume.source.SyslogUtils
-
- syslogHandler() - Constructor for class org.apache.flume.source.SyslogUDPSource.syslogHandler
-
- SyslogParser - Class in org.apache.flume.source
-
- SyslogParser() - Constructor for class org.apache.flume.source.SyslogParser
-
- SyslogSourceConfigurationConstants - Class in org.apache.flume.source
-
- syslogTcpHandler() - Constructor for class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
-
Deprecated.
- SyslogTcpSource - Class in org.apache.flume.source
-
- SyslogTcpSource() - Constructor for class org.apache.flume.source.SyslogTcpSource
-
Deprecated.
- SyslogTcpSource.syslogTcpHandler - Class in org.apache.flume.source
-
Deprecated.
- SyslogUDPSource - Class in org.apache.flume.source
-
- SyslogUDPSource() - Constructor for class org.apache.flume.source.SyslogUDPSource
-
- SyslogUDPSource.syslogHandler - Class in org.apache.flume.source
-
- SyslogUtils - Class in org.apache.flume.source
-
- SyslogUtils() - Constructor for class org.apache.flume.source.SyslogUtils
-
- SyslogUtils(boolean) - Constructor for class org.apache.flume.source.SyslogUtils
-
- SyslogUtils(Integer, Set<String>, boolean) - Constructor for class org.apache.flume.source.SyslogUtils
-
- SyslogUtils.SyslogStatus - Enum in org.apache.flume.source
-
- SYSPROP_CALLED_FROM_SERVICE - Static variable in class org.apache.flume.Constants
-
Disables the fail-fast startup behavior.
- SystemClock - Class in org.apache.flume
-
Default implementation of Clock which uses System
- SystemClock() - Constructor for class org.apache.flume.SystemClock
-
- validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
-
- validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
-
- validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
-
- validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
-
- validate() - Method in class org.apache.flume.source.scribe.LogEntry
-
- validate() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
-
- validate() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
-
- validate() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
-
- validate() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
-
- validate() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
-
- validate() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
-
- validate() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
-
- validateEvent(Event) - Method in interface org.apache.flume.tools.EventValidator
-
Validate the Event in a application specific manner
- validateSchema() - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
-
- validateSchema() - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
-
- validateSchema() - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
-
Validates the schema.
- VALUE - Static variable in class org.apache.flume.interceptor.StaticInterceptor.Constants
-
- VALUE_DEFAULT - Static variable in class org.apache.flume.interceptor.StaticInterceptor.Constants
-
- VALUE_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
-
- valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.EventStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.Priority
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.api.RpcClientFactory.ClientType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.channel.BasicTransactionSemantics.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.channel.file.encryption.CipherProviderType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.channel.file.encryption.KeyProviderType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.channel.jdbc.DatabaseType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.channel.jdbc.TransactionIsolation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.channel.ChannelConfiguration.ChannelConfigurationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.channel.ChannelSelectorConfiguration.ChannelSelectorConfigurationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.channel.ChannelSelectorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.channel.ChannelType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.ComponentConfiguration.ComponentType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.FlumeConfigurationError.ErrorOrWarning
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.FlumeConfigurationErrorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.sink.SinkConfiguration.SinkConfigurationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.sink.SinkProcessorConfiguration.SinkProcessorConfigurationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.sink.SinkProcessorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.sink.SinkType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.source.SourceConfiguration.SourceConfigurationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.conf.source.SourceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.formatter.output.PathManagerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.instrumentation.MonitoredCounterGroup.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.instrumentation.MonitoringType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.interceptor.InterceptorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.lifecycle.LifecycleState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.PollableSource.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.serialization.AvroEventDeserializer.AvroSchemaType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.serialization.DecodeErrorPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.serialization.EventDeserializerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.serialization.EventSerializerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.shared.kafka.test.PartitionOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.shared.kafka.test.PartitionTestScenario
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.sink.hbase.SimpleHbaseEventSerializer.KeyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.sink.hdfs.SequenceFileSerializerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.Sink.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.source.jms.JMSDestinationLocator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.source.jms.JMSDestinationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.source.scribe.LogEntry._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.source.scribe.ResultCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.source.SpoolDirectorySourceConfigurationConstants.ConsumeOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.source.SyslogUtils.SyslogStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.thrift.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.tools.FlumeToolType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flume.Transaction.TransactionState
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.cloudera.flume.handlers.thrift.EventStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.cloudera.flume.handlers.thrift.Priority
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.api.RpcClientFactory.ClientType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.channel.BasicTransactionSemantics.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.channel.file.encryption.CipherProviderType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.channel.file.encryption.KeyProviderType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.channel.jdbc.DatabaseType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.channel.jdbc.TransactionIsolation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.channel.ChannelConfiguration.ChannelConfigurationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.channel.ChannelSelectorConfiguration.ChannelSelectorConfigurationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.channel.ChannelSelectorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.channel.ChannelType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.ComponentConfiguration.ComponentType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.FlumeConfigurationError.ErrorOrWarning
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.FlumeConfigurationErrorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.sink.SinkConfiguration.SinkConfigurationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.sink.SinkProcessorConfiguration.SinkProcessorConfigurationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.sink.SinkProcessorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.sink.SinkType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.source.SourceConfiguration.SourceConfigurationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.conf.source.SourceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.formatter.output.PathManagerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.instrumentation.MonitoredCounterGroup.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.instrumentation.MonitoringType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.interceptor.InterceptorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.lifecycle.LifecycleState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.PollableSource.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.serialization.AvroEventDeserializer.AvroSchemaType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.serialization.DecodeErrorPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.serialization.EventDeserializerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.serialization.EventSerializerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.shared.kafka.test.PartitionOption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.shared.kafka.test.PartitionTestScenario
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.sink.hbase.SimpleHbaseEventSerializer.KeyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.sink.hdfs.SequenceFileSerializerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.Sink.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.source.jms.JMSDestinationLocator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.source.jms.JMSDestinationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.source.scribe.LogEntry._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.source.scribe.ResultCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.source.SpoolDirectorySourceConfigurationConstants.ConsumeOrder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.source.SyslogUtils.SyslogStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.thrift.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.tools.FlumeToolType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flume.Transaction.TransactionState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VERSION_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
-
- VERSION_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
-
- VersionAnnotation - Annotation Type in org.apache.flume
-
This class is about package attribute that captures
version info of Flume that was compiled.
- VersionInfo - Class in org.apache.flume.tools
-
- VersionInfo() - Constructor for class org.apache.flume.tools.VersionInfo
-