A B C D E F G H I J L M N O P Q R S T U V W Z

A

AbstractDistributedIndexServer - Class in org.apache.blur.manager.indexserver
 
AbstractDistributedIndexServer(ClusterStatus, Configuration, String, String) - Constructor for class org.apache.blur.manager.indexserver.AbstractDistributedIndexServer
 
AbstractIndexServer - Class in org.apache.blur.manager.indexserver
 
AbstractIndexServer() - Constructor for class org.apache.blur.manager.indexserver.AbstractIndexServer
 
action() - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus.Action
 
addBlurResultIterable(BlurResultIterable) - Method in class org.apache.blur.manager.results.BlurResultIterableMultiple
 
addColumn(String, String) - Method in class org.apache.blur.utils.BlurThriftRecord
 
addColumn(String, String) - Method in interface org.apache.blur.utils.ReaderBlurRecord
 
addColumnDefinition(String, ColumnDefinition) - Method in class org.apache.blur.server.FilteredBlurServer
 
addColumnDefinition(String, ColumnDefinition) - Method in class org.apache.blur.thrift.TableAdmin
 
AliasBlurFilterCache - Class in org.apache.blur.manager
This implementation on BlurFilterCache does nothing and it is the default BlurFilterCache.
AliasBlurFilterCache(BlurConfiguration) - Constructor for class org.apache.blur.manager.AliasBlurFilterCache
 
alignObjectSize(long) - Static method in class org.apache.blur.utils.RamUsageEstimator
Aligns an object size to be the next multiple of RamUsageEstimator.NUM_BYTES_OBJECT_ALIGNMENT.
appendColumns(String, Record) - Method in class org.apache.blur.manager.writer.MutatableAction
 
attachThread(String) - Method in class org.apache.blur.manager.status.QueryStatus
 

B

BaseCompositeReaderUtil - Class in org.apache.lucene.index
 
BaseCompositeReaderUtil() - Constructor for class org.apache.lucene.index.BaseCompositeReaderUtil
 
binaryField(FieldInfo, byte[]) - Method in class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
 
BlurControllerServer - Class in org.apache.blur.thrift
 
BlurControllerServer() - Constructor for class org.apache.blur.thrift.BlurControllerServer
 
BlurControllerServer.BlurClient - Class in org.apache.blur.thrift
 
BlurControllerServer.BlurClient() - Constructor for class org.apache.blur.thrift.BlurControllerServer.BlurClient
 
BlurControllerServer.BlurClientRemote - Class in org.apache.blur.thrift
 
BlurControllerServer.BlurClientRemote(int) - Constructor for class org.apache.blur.thrift.BlurControllerServer.BlurClientRemote
 
BlurExecutorCompletionService<T> - Class in org.apache.blur.utils
 
BlurExecutorCompletionService(Executor, BlurExecutorCompletionService.Cancel) - Constructor for class org.apache.blur.utils.BlurExecutorCompletionService
 
BlurExecutorCompletionService.Cancel - Interface in org.apache.blur.utils
 
BlurFilterCache - Class in org.apache.blur.manager
The BlurFilterCache class provides the ability to cache pre and post filters on a per table basis.
BlurFilterCache(BlurConfiguration) - Constructor for class org.apache.blur.manager.BlurFilterCache
 
BlurFilterCache.FilterParser - Interface in org.apache.blur.manager
 
BlurHighlighter - Class in org.apache.blur.manager
 
BlurHighlighter(Query, FieldManager, Selector) - Constructor for class org.apache.blur.manager.BlurHighlighter
 
BlurHighlighter() - Constructor for class org.apache.blur.manager.BlurHighlighter
 
BlurIndex - Class in org.apache.blur.manager.writer
 
BlurIndex(ShardContext, Directory, SharedMergeScheduler, ExecutorService, BlurIndexCloser, BlurIndexWarmup) - Constructor for class org.apache.blur.manager.writer.BlurIndex
 
BlurIndexCloser - Class in org.apache.blur.manager.writer
 
BlurIndexCloser() - Constructor for class org.apache.blur.manager.writer.BlurIndexCloser
 
BlurIndexReaderWarmer - Class in org.apache.blur.manager.writer
 
BlurIndexReaderWarmer(ShardContext, AtomicBoolean, BlurIndexWarmup) - Constructor for class org.apache.blur.manager.writer.BlurIndexReaderWarmer
 
BlurIndexReadOnly - Class in org.apache.blur.manager.writer
 
BlurIndexReadOnly(BlurIndex) - Constructor for class org.apache.blur.manager.writer.BlurIndexReadOnly
 
BlurIndexRefresher - Class in org.apache.blur.manager.writer
 
BlurIndexRefresher() - Constructor for class org.apache.blur.manager.writer.BlurIndexRefresher
 
BlurIndexSimpleWriter - Class in org.apache.blur.manager.writer
 
BlurIndexSimpleWriter(ShardContext, Directory, SharedMergeScheduler, ExecutorService, BlurIndexCloser, BlurIndexWarmup) - Constructor for class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
BlurIndexWarmup - Class in org.apache.blur.manager.indexserver
 
BlurIndexWarmup(long) - Constructor for class org.apache.blur.manager.indexserver.BlurIndexWarmup
 
BlurPartitioner - Class in org.apache.blur.manager
The BlurPartitioner class is a Hadoop Partitioner implementation for Blur.
BlurPartitioner() - Constructor for class org.apache.blur.manager.BlurPartitioner
 
BlurQueryChecker - Class in org.apache.blur.manager
The BlurQueryChecker class check the BlurQuery for valid settings before allowing the query to be executed.
BlurQueryChecker(BlurConfiguration) - Constructor for class org.apache.blur.manager.BlurQueryChecker
Reads the BlurConstants BLUR_QUERY_MAX_RESULTS_FETCH, BLUR_QUERY_MAX_ROW_FETCH, and BLUR_QUERY_MAX_RECORD_FETCH to validate the BlurQuery before execution.
BlurResultComparator - Class in org.apache.blur.manager.results
 
BlurResultComparator() - Constructor for class org.apache.blur.manager.results.BlurResultComparator
 
BlurResultIterable - Interface in org.apache.blur.manager.results
 
BlurResultIterableClient - Class in org.apache.blur.manager.results
 
BlurResultIterableClient(Connection, Blur.Client, String, BlurQuery, AtomicLongArray, int) - Constructor for class org.apache.blur.manager.results.BlurResultIterableClient
 
BlurResultIterableClient.SearchIterator - Class in org.apache.blur.manager.results
 
BlurResultIterableClient.SearchIterator() - Constructor for class org.apache.blur.manager.results.BlurResultIterableClient.SearchIterator
 
BlurResultIterableMultiple - Class in org.apache.blur.manager.results
 
BlurResultIterableMultiple() - Constructor for class org.apache.blur.manager.results.BlurResultIterableMultiple
 
BlurResultIterableMultiple.MultipleHitsIterator - Class in org.apache.blur.manager.results
 
BlurResultIterableMultiple.MultipleHitsIterator(List<BlurResultIterable>) - Constructor for class org.apache.blur.manager.results.BlurResultIterableMultiple.MultipleHitsIterator
 
BlurResultIterableSearcher - Class in org.apache.blur.manager.results
 
BlurResultIterableSearcher(AtomicBoolean, Query, String, String, IndexSearcherClosable, Selector, boolean, boolean, int, int, TableContext, Sort, DeepPagingCache) - Constructor for class org.apache.blur.manager.results.BlurResultIterableSearcher
 
BlurResultIterableSimple - Class in org.apache.blur.manager.results
 
BlurResultIterableSimple(String, List<BlurResult>) - Constructor for class org.apache.blur.manager.results.BlurResultIterableSimple
 
BlurResultPeekableIteratorComparator - Class in org.apache.blur.manager.results
 
BlurResultPeekableIteratorComparator() - Constructor for class org.apache.blur.manager.results.BlurResultPeekableIteratorComparator
 
BlurServerContext - Class in org.apache.blur.server
 
BlurServerContext(SocketAddress, SocketAddress) - Constructor for class org.apache.blur.server.BlurServerContext
 
BlurServerShutDown - Class in org.apache.blur.manager.indexserver
 
BlurServerShutDown() - Constructor for class org.apache.blur.manager.indexserver.BlurServerShutDown
 
BlurServerShutDown.BlurShutdown - Interface in org.apache.blur.manager.indexserver
 
BlurShardServer - Class in org.apache.blur.thrift
 
BlurShardServer() - Constructor for class org.apache.blur.thrift.BlurShardServer
 
BlurThriftRecord - Class in org.apache.blur.utils
 
BlurThriftRecord() - Constructor for class org.apache.blur.utils.BlurThriftRecord
 
BlurUtil - Class in org.apache.blur.utils
 
BlurUtil() - Constructor for class org.apache.blur.utils.BlurUtil
 

C

cache(String, BlurQuery, BlurResults) - Method in class org.apache.blur.utils.QueryCache
 
call(INPUT) - Method in interface org.apache.blur.utils.ForkJoin.ParallelCall
 
cancel() - Method in interface org.apache.blur.utils.BlurExecutorCompletionService.Cancel
 
CANCEL - Static variable in class org.apache.blur.utils.ForkJoin
 
cancelAll() - Method in class org.apache.blur.utils.BlurExecutorCompletionService
 
cancelQuery(String, String) - Method in class org.apache.blur.manager.IndexManager
 
cancelQuery() - Method in class org.apache.blur.manager.status.QueryStatus
 
cancelQuery(String, String) - Method in class org.apache.blur.manager.status.QueryStatusManager
 
cancelQuery(String, String) - Method in class org.apache.blur.server.FilteredBlurServer
 
cancelQuery(String, String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
cancelQuery(String, String) - Method in class org.apache.blur.thrift.BlurShardServer
 
checkDouble(String, Number, Query) - Static method in class org.apache.blur.utils.HighlightHelper
 
checkFloat(String, Number, Query) - Static method in class org.apache.blur.utils.HighlightHelper
 
checkForUpdates(String) - Method in class org.apache.blur.thrift.TableAdmin
 
checkForUpdates(String, String) - Method in class org.apache.blur.thrift.TableAdmin
 
checkInteger(String, Number, Query) - Static method in class org.apache.blur.utils.HighlightHelper
 
checkLong(String, Number, Query) - Static method in class org.apache.blur.utils.HighlightHelper
 
checkQuery(BlurQuery) - Method in class org.apache.blur.manager.BlurQueryChecker
Checks the query by running validation against the BlurQuery and the Selector provided.
checkTable(String) - Method in class org.apache.blur.thrift.TableAdmin
 
checkTable(String, String) - Method in class org.apache.blur.thrift.TableAdmin
 
ClassNameFilter - Interface in org.apache.blur.utils
 
cleanupOldDirs() - Method in class org.apache.blur.manager.writer.IndexImporter
 
clear() - Static method in class org.apache.blur.server.TableContext
 
clear(String) - Static method in class org.apache.blur.server.TableContext
 
close() - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
close() - Method in class org.apache.blur.manager.IndexManager
 
close() - Method in interface org.apache.blur.manager.IndexServer
Closes the index server.
close() - Method in class org.apache.blur.manager.indexserver.CloseableExecutorService
 
close(ExecutorService) - Static method in class org.apache.blur.manager.indexserver.CloseableExecutorService
 
close() - Method in class org.apache.blur.manager.indexserver.DistributedIndexServer
 
close() - Method in class org.apache.blur.manager.indexserver.LocalIndexServer
 
close() - Method in class org.apache.blur.manager.indexserver.ShardStateManager
 
close() - Method in class org.apache.blur.manager.results.BlurResultIterableClient
 
close() - Method in class org.apache.blur.manager.results.BlurResultIterableMultiple
 
close() - Method in class org.apache.blur.manager.results.BlurResultIterableSearcher
 
close() - Method in class org.apache.blur.manager.results.BlurResultIterableSimple
 
close() - Method in class org.apache.blur.manager.status.QueryStatusManager
 
close() - Method in class org.apache.blur.manager.writer.BlurIndex
 
close() - Method in class org.apache.blur.manager.writer.BlurIndexCloser
 
close(IndexReader) - Method in class org.apache.blur.manager.writer.BlurIndexCloser
 
close() - Method in class org.apache.blur.manager.writer.BlurIndexReadOnly
 
close() - Method in class org.apache.blur.manager.writer.BlurIndexRefresher
 
close() - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
close() - Method in class org.apache.blur.manager.writer.IndexImporter
 
close() - Method in class org.apache.blur.manager.writer.MutationQueueProcessor
 
close() - Method in class org.apache.blur.manager.writer.SharedMergeScheduler
 
close() - Method in class org.apache.blur.server.IndexSearcherClosable
 
close() - Method in class org.apache.blur.server.ShardServerContext
Closes this context, this happens when the client closes it's connect to the server.
close() - Method in class org.apache.blur.thrift.BlurControllerServer
 
close() - Method in class org.apache.blur.thrift.BlurShardServer
 
close() - Method in class org.apache.blur.thrift.ThriftServer
 
close() - Method in class org.apache.blur.trace.hdfs.HdfsTraceStorage
 
CloseableExecutorService - Class in org.apache.blur.manager.indexserver
 
CloseableExecutorService(ExecutorService) - Constructor for class org.apache.blur.manager.indexserver.CloseableExecutorService
 
closed(String, String) - Method in class org.apache.blur.manager.indexserver.ShardStateManager
 
closeQuietly(Closeable) - Static method in class org.apache.blur.server.ShardServerContext
 
closing(String, String, BlurIndex) - Method in class org.apache.blur.manager.AliasBlurFilterCache
 
closing(String, String, BlurIndex) - Method in class org.apache.blur.manager.BlurFilterCache
Notifies the cache that the index is closing on this shard server.
closing(String, String, BlurIndex) - Method in class org.apache.blur.manager.DefaultBlurFilterCache
 
closing(String, String) - Method in class org.apache.blur.manager.indexserver.ShardStateManager
 
closingError(String, String) - Method in class org.apache.blur.manager.indexserver.ShardStateManager
 
ClusterStatus - Class in org.apache.blur.manager.clusterstatus
 
ClusterStatus() - Constructor for class org.apache.blur.manager.clusterstatus.ClusterStatus
 
ClusterStatus.Action - Class in org.apache.blur.manager.clusterstatus
 
ClusterStatus.Action() - Constructor for class org.apache.blur.manager.clusterstatus.ClusterStatus.Action
 
collapseShardsTo(int) - Method in class org.apache.blur.utils.TableShardCountCollapser
 
compare(BlurResult, BlurResult) - Method in class org.apache.blur.manager.results.BlurResultComparator
 
compare(PeekableIterator<BlurResult, BlurException>, PeekableIterator<BlurResult, BlurException>) - Method in class org.apache.blur.manager.results.BlurResultPeekableIteratorComparator
 
compareTo(QueryStatus) - Method in class org.apache.blur.manager.status.QueryStatus
 
Configurable - Interface in org.apache.blur.server
 
configuration() - Method in class org.apache.blur.server.FilteredBlurServer
 
configuration() - Method in class org.apache.blur.thrift.TableAdmin
 
configure(T) - Static method in class org.apache.blur.utils.BlurUtil
 
ControllerServerContext - Class in org.apache.blur.server
The thrift session that holds the connection string of the client.
ControllerServerContext(SocketAddress, SocketAddress) - Constructor for class org.apache.blur.server.ControllerServerContext
 
ControllerServerEventHandler - Class in org.apache.blur.server
ConrtollerServerContext is the session manager for the controller servers.
ControllerServerEventHandler() - Constructor for class org.apache.blur.server.ControllerServerEventHandler
 
controllerServerList() - Method in class org.apache.blur.server.FilteredBlurServer
 
controllerServerList() - Method in class org.apache.blur.thrift.TableAdmin
 
convert(Iterator<T>) - Static method in class org.apache.blur.utils.BlurUtil
 
convert(F) - Method in interface org.apache.blur.utils.Converter
 
Converter<F,T,E extends Exception> - Interface in org.apache.blur.utils
 
convertToBlurResults(BlurResultIterable, BlurQuery, AtomicLongArray, ExecutorService, Selector, String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
convertToHits(BlurResultIterable, BlurQuery, AtomicLongArray, ExecutorService, Selector, Blur.Iface, String) - Static method in class org.apache.blur.utils.BlurUtil
 
convertToSortField(Object) - Static method in class org.apache.blur.utils.BlurUtil
 
convertToSortFields(Object[]) - Static method in class org.apache.blur.utils.BlurUtil
 
countDocuments(IndexReader, Term) - Static method in class org.apache.blur.utils.BlurUtil
 
create(TableContext, String) - Static method in class org.apache.blur.server.ShardContext
 
create(TableDescriptor) - Static method in class org.apache.blur.server.TableContext
 
createContext(TProtocol, TProtocol, Object) - Method in class org.apache.blur.server.ControllerServerEventHandler
 
createContext(TProtocol, TProtocol, Object) - Method in class org.apache.blur.server.ShardServerEventHandler
 
createDistributedLayout(String, List<String>, List<String>, List<String>) - Method in interface org.apache.blur.manager.indexserver.DistributedLayoutFactory
 
createDistributedLayout(String, List<String>, List<String>, List<String>) - Method in class org.apache.blur.manager.indexserver.MasterBasedDistributedLayoutFactory
 
CreateGarbage - Class in org.apache.blur.utils
 
CreateGarbage() - Constructor for class org.apache.blur.utils.CreateGarbage
 
createIfMissing(ZooKeeper, String) - Static method in class org.apache.blur.utils.BlurUtil
 
createPath(ZooKeeper, String, byte[]) - Static method in class org.apache.blur.utils.BlurUtil
 
createPath(FileSystem, Path) - Static method in class org.apache.blur.utils.BlurUtil
 
createRecordId(String) - Static method in class org.apache.blur.manager.writer.MutatableAction
 
createRowId(String) - Static method in class org.apache.blur.manager.writer.MutatableAction
 
createRowId(String) - Static method in class org.apache.blur.utils.RowDocumentUtil
 
createServer(int, BlurConfiguration, boolean) - Static method in class org.apache.blur.thrift.ThriftBlurControllerServer
 
createServer(int, BlurConfiguration, boolean) - Static method in class org.apache.blur.thrift.ThriftBlurShardServer
 
createSnapshot(String) - Method in class org.apache.blur.manager.writer.BlurIndex
 
createSnapshot(String) - Method in class org.apache.blur.manager.writer.BlurIndexReadOnly
 
createSnapshot(String) - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
createSnapshot(String, DirectoryReader, String) - Method in class org.apache.blur.manager.writer.SnapshotIndexDeletionPolicy
 
createSnapshot(String, String) - Method in class org.apache.blur.server.FilteredBlurServer
 
createSnapshot(String, String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
createSnapshot(String, String) - Method in class org.apache.blur.thrift.BlurShardServer
 
createTable(TableDescriptor) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
createTable(TableDescriptor) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
createTable(TableDescriptor) - Method in class org.apache.blur.server.example.DisableTableAdminServer
 
createTable(TableDescriptor) - Method in class org.apache.blur.server.FilteredBlurServer
 
createTable(TableDescriptor) - Method in class org.apache.blur.thrift.TableAdmin
 
currentQueries(String) - Method in class org.apache.blur.manager.IndexManager
 
currentQueries(String) - Method in class org.apache.blur.manager.status.QueryStatusManager
 

D

deattachThread(String) - Method in class org.apache.blur.manager.status.QueryStatus
 
DEBUG_RUN_SLOW - Static variable in class org.apache.blur.manager.IndexManager
 
DefaultBlurFilterCache - Class in org.apache.blur.manager
This implementation on BlurFilterCache does nothing and it is the default BlurFilterCache.
DefaultBlurFilterCache(BlurConfiguration) - Constructor for class org.apache.blur.manager.DefaultBlurFilterCache
 
DefaultBlurIndexWarmup - Class in org.apache.blur.manager.indexserver
 
DefaultBlurIndexWarmup(long) - Constructor for class org.apache.blur.manager.indexserver.DefaultBlurIndexWarmup
 
deleteContext(ServerContext, TProtocol, TProtocol) - Method in class org.apache.blur.server.ControllerServerEventHandler
 
deleteContext(ServerContext, TProtocol, TProtocol) - Method in class org.apache.blur.server.ShardServerEventHandler
 
deleteRecord(String, String) - Method in class org.apache.blur.manager.writer.MutatableAction
 
deleteRow(String) - Method in class org.apache.blur.manager.writer.MutatableAction
 
describe(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
describe(String) - Method in class org.apache.blur.thrift.TableAdmin
 
description - Variable in enum org.apache.blur.utils.RamUsageEstimator.JvmFeature
 
disableTable(String, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
disableTable(String, String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
disableTable(String) - Method in class org.apache.blur.server.example.DisableTableAdminServer
 
disableTable(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
disableTable(String) - Method in class org.apache.blur.thrift.TableAdmin
 
DisableTableAdminServer - Class in org.apache.blur.server.example
 
DisableTableAdminServer(BlurConfiguration, Blur.Iface, boolean) - Constructor for class org.apache.blur.server.example.DisableTableAdminServer
 
DistributedIndexServer - Class in org.apache.blur.manager.indexserver
 
DistributedIndexServer(Configuration, ZooKeeper, ClusterStatus, BlurIndexWarmup, BlurFilterCache, BlockCacheDirectoryFactory, DistributedLayoutFactory, String, String, long, int, int, int, int, boolean, int) - Constructor for class org.apache.blur.manager.indexserver.DistributedIndexServer
 
DistributedIndexServer.ReleaseReader - Interface in org.apache.blur.manager.indexserver
 
DistributedLayout - Interface in org.apache.blur.manager.indexserver
 
DistributedLayoutFactory - Interface in org.apache.blur.manager.indexserver
 
DistributedLayoutFactoryImpl - Class in org.apache.blur.manager.indexserver
 
DistributedLayoutFactoryImpl() - Constructor for class org.apache.blur.manager.indexserver.DistributedLayoutFactoryImpl
 
DistributedLayoutManager - Class in org.apache.blur.manager.indexserver
 
DistributedLayoutManager() - Constructor for class org.apache.blur.manager.indexserver.DistributedLayoutManager
 
doPostCommit(IndexWriter) - Method in class org.apache.blur.manager.writer.IndexAction
 
doPostCommit(IndexWriter) - Method in class org.apache.blur.manager.writer.MutatableAction
 
doPostRollback(IndexWriter) - Method in class org.apache.blur.manager.writer.IndexAction
 
doPostRollback(IndexWriter) - Method in class org.apache.blur.manager.writer.MutatableAction
 
doPreCommit(IndexSearcherClosable, IndexWriter) - Method in class org.apache.blur.manager.writer.IndexAction
 
doPreCommit(IndexSearcherClosable, IndexWriter) - Method in class org.apache.blur.manager.writer.MutatableAction
 
doPreRollback(IndexWriter) - Method in class org.apache.blur.manager.writer.IndexAction
 
doPreRollback(IndexWriter) - Method in class org.apache.blur.manager.writer.MutatableAction
 
doubleField(FieldInfo, double) - Method in class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
 

E

enable() - Static method in class org.apache.blur.utils.MemoryReporter
 
enableTable(String, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
enableTable(String, String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
enableTable(String) - Method in class org.apache.blur.server.example.DisableTableAdminServer
 
enableTable(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
enableTable(String) - Method in class org.apache.blur.thrift.TableAdmin
 
enqueue(List<RowMutation>) - Method in class org.apache.blur.manager.IndexManager
 
enqueue(RowMutation) - Method in class org.apache.blur.manager.IndexManager
 
enqueue(List<RowMutation>) - Method in class org.apache.blur.manager.writer.BlurIndex
 
enqueue(List<RowMutation>) - Method in class org.apache.blur.manager.writer.BlurIndexReadOnly
 
enqueue(List<RowMutation>) - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
enqueueMutate(RowMutation) - Method in class org.apache.blur.server.FilteredBlurServer
 
enqueueMutate(RowMutation) - Method in class org.apache.blur.thrift.BlurControllerServer
 
enqueueMutate(RowMutation) - Method in class org.apache.blur.thrift.BlurShardServer
 
enqueueMutateBatch(List<RowMutation>) - Method in class org.apache.blur.server.FilteredBlurServer
 
enqueueMutateBatch(List<RowMutation>) - Method in class org.apache.blur.thrift.BlurControllerServer
 
enqueueMutateBatch(List<RowMutation>) - Method in class org.apache.blur.thrift.BlurShardServer
 
equals(Object) - Method in class org.apache.blur.utils.QueryCacheKey
 
execute(String, BlurCommand<T>, int, long, long) - Method in class org.apache.blur.thrift.BlurControllerServer.BlurClient
 
execute(String, BlurCommand<T>, int, long, long) - Method in class org.apache.blur.thrift.BlurControllerServer.BlurClientRemote
 
execute(ExecutorService, Iterable<INPUT>, ForkJoin.ParallelCall<INPUT, OUTPUT>) - Static method in class org.apache.blur.utils.ForkJoin
 
execute(ExecutorService, Iterable<INPUT>, ForkJoin.ParallelCall<INPUT, OUTPUT>, BlurExecutorCompletionService.Cancel) - Static method in class org.apache.blur.utils.ForkJoin
 
exists(boolean, String, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
exists(boolean, String, String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 

F

fetchDocuments(IndexReader, ResetableDocumentStoredFieldVisitor, Selector, int, String, Term, Filter, AtomicBoolean, AtomicInteger, BlurHighlighter) - Static method in class org.apache.blur.utils.BlurUtil
NOTE: This is a potentially dangerous call, it will return all the documents that match the term.
fetchPostFilter(String, String) - Method in class org.apache.blur.manager.AliasBlurFilterCache
 
fetchPostFilter(String, String) - Method in class org.apache.blur.manager.BlurFilterCache
The fetchPostFilter method fetches the cache post-filter (or Row Filter) before attempting to execute the filter provided by the user.
fetchPostFilter(String, String) - Method in class org.apache.blur.manager.DefaultBlurFilterCache
 
fetchPreFilter(String, String) - Method in class org.apache.blur.manager.AliasBlurFilterCache
 
fetchPreFilter(String, String) - Method in class org.apache.blur.manager.BlurFilterCache
The fetchPreFilter method fetches the cache pre-filter (or Record Filter) before attempting to execute the filter provided by the user.
fetchPreFilter(String, String) - Method in class org.apache.blur.manager.DefaultBlurFilterCache
 
fetchRow(String, Selector, FetchResult) - Method in class org.apache.blur.manager.IndexManager
 
fetchRow(IndexReader, String, String, Selector, FetchResult, Query, int, TableContext, Filter) - Static method in class org.apache.blur.manager.IndexManager
 
fetchRow(IndexReader, String, String, Selector, FetchResult, Query, FieldManager, int, TableContext, Filter) - Static method in class org.apache.blur.manager.IndexManager
 
fetchRow(String, Selector) - Method in class org.apache.blur.manager.results.LazyBlurResult
 
fetchRow(String, Selector) - Method in class org.apache.blur.server.FilteredBlurServer
 
fetchRow(String, Selector) - Method in class org.apache.blur.thrift.BlurControllerServer
 
fetchRow(String, Selector) - Method in class org.apache.blur.thrift.BlurShardServer
 
fetchRowBatch(String, List<Selector>) - Method in class org.apache.blur.manager.IndexManager
 
fetchRowBatch(String, List<Selector>) - Method in class org.apache.blur.server.FilteredBlurServer
 
fetchRowBatch(String, List<Selector>) - Method in class org.apache.blur.thrift.BlurControllerServer
 
fetchRowBatch(String, List<Selector>) - Method in class org.apache.blur.thrift.BlurShardServer
 
FilteredBlurServer - Class in org.apache.blur.server
 
FilteredBlurServer(BlurConfiguration, Blur.Iface, boolean) - Constructor for class org.apache.blur.server.FilteredBlurServer
 
floatField(FieldInfo, float) - Method in class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
 
ForkJoin - Class in org.apache.blur.utils
 
ForkJoin() - Constructor for class org.apache.blur.utils.ForkJoin
 
ForkJoin.Merger<OUTPUT> - Interface in org.apache.blur.utils
 
ForkJoin.ParallelCall<INPUT,OUTPUT> - Interface in org.apache.blur.utils
 
ForkJoin.ParallelReturn<OUTPUT> - Interface in org.apache.blur.utils
 
fromBytes(byte[]) - Static method in class org.apache.blur.utils.BlurUtil
 
fromBytes(byte[], int, int) - Static method in class org.apache.blur.utils.BlurUtil
 

G

GCAction - Interface in org.apache.blur.utils
The GCAction interface is used to implement an action that needs to be taken to prevent an OutOfMemoryError exception.
GCWatcher - Class in org.apache.blur.utils
 
GCWatcher() - Constructor for class org.apache.blur.utils.GCWatcher
 
GCWatcherJdk6 - Class in org.apache.blur.utils
 
GCWatcherJdk7 - Class in org.apache.blur.utils
 
get(QueryCacheKey) - Method in class org.apache.blur.utils.QueryCache
 
getAcceptQueueSizePerThread() - Method in class org.apache.blur.thrift.ThriftServer
 
getArgsStr(Object[], String, BlurUtil.LoggerArgsState) - Static method in class org.apache.blur.utils.BlurUtil
 
getArgsStr(Object[], BlurUtil.LoggerArgsState) - Static method in class org.apache.blur.utils.BlurUtil
 
getArgsStr(Object, BlurUtil.LoggerArgsState) - Static method in class org.apache.blur.utils.BlurUtil
 
getArgsStr(TBase, BlurUtil.LoggerArgsState) - Static method in class org.apache.blur.utils.BlurUtil
 
getAtomicLongArraySameLengthAsList(List<?>) - Static method in class org.apache.blur.utils.BlurUtil
 
getAtomicReader(IndexReader) - Static method in class org.apache.blur.utils.BlurUtil
 
getBasePath() - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getBindInetSocketAddress(String, int) - Static method in class org.apache.blur.thrift.ThriftServer
 
getBlurConfiguration() - Method in class org.apache.blur.server.TableContext
 
getBlurResults(BlurQuery) - Method in class org.apache.blur.utils.QueryCacheEntry
 
getClient() - Method in class org.apache.blur.manager.results.BlurResultIterableClient
 
getClient() - Method in class org.apache.blur.manager.results.LazyBlurResult
 
getClient() - Method in class org.apache.blur.thrift.BlurControllerServer
 
getCluster(boolean, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
getCluster(boolean, String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
getClusterList(boolean) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
getClusterList(boolean) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
getClusterPath(String) - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getClustersPath() - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getClusterStatus() - Method in class org.apache.blur.thrift.TableAdmin
 
getCollapsePossibilities() - Method in class org.apache.blur.utils.TableShardCountCollapser
 
getConfiguration() - Method in class org.apache.blur.server.TableContext
 
getConnectionString(String) - Method in class org.apache.blur.server.BlurServerContext
 
getControllerServerContext() - Static method in class org.apache.blur.server.ControllerServerContext
Gets the ControllerServerContext for this Thread.
getControllerServerList() - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
getControllerServerList() - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
getControllersPath() - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getDataFetchThreadCount() - Method in class org.apache.blur.thrift.BlurShardServer
 
getDefaultFieldName() - Method in class org.apache.blur.server.TableContext
 
getDefaultPrimeDocTerm() - Method in class org.apache.blur.server.TableContext
 
getDefaultScoreType() - Method in class org.apache.blur.server.TableContext
 
getDescriptor() - Method in class org.apache.blur.server.TableContext
 
getDirectory() - Method in class org.apache.blur.server.IndexSearcherClosable
 
getDirectory() - Method in class org.apache.blur.server.ShardContext
 
getDistributedLayoutFactory(BlurConfiguration, String, ZooKeeper) - Static method in class org.apache.blur.manager.indexserver.DistributedLayoutFactoryImpl
 
getDoc(FieldManager, String, Record) - Static method in class org.apache.blur.utils.RowDocumentUtil
 
getDocs(Row, FieldManager) - Static method in class org.apache.blur.utils.RowDocumentUtil
 
getDocument() - Method in class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
Retrieve the visited document.
getErrorResponseLogMessage(String, String, String, String, double, User) - Static method in class org.apache.blur.utils.BlurUtil
 
getEventHandler() - Method in class org.apache.blur.thrift.ThriftServer
 
getFieldManager() - Method in class org.apache.blur.manager.BlurHighlighter
 
getFieldManager() - Method in class org.apache.blur.server.TableContext
 
getFieldSelector(Selector) - Static method in class org.apache.blur.manager.IndexManager
 
getFilter() - Method in class org.apache.blur.manager.ReadInterceptor
 
getFinishedTime() - Method in class org.apache.blur.manager.status.QueryStatus
 
getHdfsDirPath() - Method in class org.apache.blur.server.ShardContext
 
getHighlightQuery() - Method in class org.apache.blur.manager.BlurHighlighter
 
getIface() - Method in class org.apache.blur.thrift.ThriftServer
 
getIndexDeletionPolicy() - Method in class org.apache.blur.server.TableContext
 
getIndexes(String) - Method in class org.apache.blur.manager.indexserver.DistributedIndexServer
 
getIndexes(String) - Method in interface org.apache.blur.manager.IndexServer
Gets a map of the index readers for current running node.
getIndexes(String) - Method in class org.apache.blur.manager.indexserver.LocalIndexServer
 
getIndexMemoryUsage() - Method in class org.apache.blur.manager.writer.BlurIndex
 
getIndexSearcher() - Method in class org.apache.blur.manager.writer.BlurIndex
 
getIndexSearcher() - Method in class org.apache.blur.manager.writer.BlurIndexReadOnly
 
getIndexSearcher() - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
getIndexSearcherClosable(String, String) - Method in class org.apache.blur.server.ShardServerContext
Gets the cached IndexSearcherClosable (if any) for the given table and shard.
getIndexServer() - Method in class org.apache.blur.manager.IndexManager
 
getIndexWarmup(BlurConfiguration) - Static method in class org.apache.blur.manager.indexserver.BlurIndexWarmup
 
getInstance(String, Class<T>) - Static method in class org.apache.blur.utils.BlurUtil
 
getLayout() - Method in interface org.apache.blur.manager.indexserver.DistributedLayout
 
getLayout() - Method in class org.apache.blur.manager.indexserver.DistributedLayoutManager
 
getLayoutCache() - Method in interface org.apache.blur.manager.indexserver.DistributedLayoutFactory
 
getLayoutCache() - Method in class org.apache.blur.manager.indexserver.MasterBasedDistributedLayoutFactory
 
getList(AtomicLongArray) - Static method in class org.apache.blur.utils.BlurUtil
 
getLocalPort() - Method in class org.apache.blur.thrift.ThriftServer
 
getMaxFrameSize() - Method in class org.apache.blur.thrift.ThriftServer
 
getMaxQueryCacheElements() - Method in class org.apache.blur.thrift.BlurShardServer
 
getMaxReadBufferBytes() - Method in class org.apache.blur.thrift.ThriftServer
 
getMaxRecordsPerRowFetchRequest() - Method in class org.apache.blur.thrift.TableAdmin
 
getMaxTimeToLive() - Method in class org.apache.blur.thrift.BlurShardServer
 
getMergeScheduler() - Method in class org.apache.blur.manager.writer.SharedMergeScheduler
 
getMetrics() - Static method in class org.apache.blur.utils.MemoryReporter
 
getNodeName() - Method in class org.apache.blur.manager.indexserver.AbstractDistributedIndexServer
 
getNodeName() - Method in interface org.apache.blur.manager.IndexServer
Gets the current nodes name.
getNodeName() - Method in class org.apache.blur.manager.indexserver.LocalIndexServer
 
getNodeName() - Method in class org.apache.blur.thrift.ThriftServer
 
getNodeName(BlurConfiguration, String) - Static method in class org.apache.blur.thrift.ThriftServer
 
getNodes() - Method in class org.apache.blur.manager.indexserver.DistributedLayoutManager
 
getNodesOffline() - Method in class org.apache.blur.manager.indexserver.DistributedLayoutManager
 
getNormalizedBlurQueryKey(String, BlurQuery) - Static method in class org.apache.blur.utils.QueryCache
 
getOfflineShardServers(boolean, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
getOnlineControllerList() - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
getOnlineControllerList() - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
getOnlineControllersPath() - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getOnlineShardServers(boolean, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
getOnlineShardServers(boolean, String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
getOnlineShardsPath(String) - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getPartition(Text, Writable, int) - Method in class org.apache.blur.manager.BlurPartitioner
Gets the partition or reducer from the the rowId, based on the number of shards in the table.
getPauseWarmup() - Static method in class org.apache.blur.manager.indexserver.DistributedIndexServer
 
getPid() - Static method in class org.apache.blur.utils.BlurUtil
 
getPosition() - Method in class org.apache.blur.manager.results.BlurResultIterableClient.SearchIterator
 
getPosition() - Method in class org.apache.blur.manager.results.BlurResultIterableMultiple.MultipleHitsIterator
 
getPosition() - Method in class org.apache.blur.manager.results.PeekableIterator
 
getPosition() - Method in class org.apache.blur.utils.IteratorConverter
 
getPostTag() - Method in class org.apache.blur.manager.BlurHighlighter
 
getPreTag() - Method in class org.apache.blur.manager.BlurHighlighter
 
getQuery() - Method in class org.apache.blur.utils.QueryCacheKey
 
getQueryStatus() - Method in class org.apache.blur.manager.status.QueryStatus
 
getReadInterceptor() - Method in class org.apache.blur.server.TableContext
 
getRecord(Document) - Static method in class org.apache.blur.utils.RowDocumentUtil
 
getRecordCount(String) - Method in class org.apache.blur.manager.indexserver.AbstractIndexServer
 
getRecordCount(String) - Method in interface org.apache.blur.manager.IndexServer
Gets the record count of the table.
getRecordCount() - Method in class org.apache.blur.manager.writer.BlurIndex
 
getRegisteredShardsPath(String) - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getRemainingCount() - Method in class org.apache.blur.utils.BlurExecutorCompletionService
 
getRemoteFetchCount() - Method in class org.apache.blur.thrift.BlurControllerServer
 
getRemoteSocketAddress() - Method in class org.apache.blur.server.BlurServerContext
 
getRequestContentsJson(String, String) - Method in class org.apache.blur.trace.hdfs.HdfsTraceStorage
 
getRequestIds(String) - Method in class org.apache.blur.trace.hdfs.HdfsTraceStorage
 
getRequestLogMessage(String, String, String, String, User) - Static method in class org.apache.blur.utils.BlurUtil
 
getResponseLogMessage(String, String, String, String, double, User, boolean) - Static method in class org.apache.blur.utils.BlurUtil
 
getResultThrowException(Future<T>, Object...) - Method in class org.apache.blur.utils.BlurExecutorCompletionService
 
getRocalSocketAddress() - Method in class org.apache.blur.server.BlurServerContext
 
getRow(Iterable<Document>) - Static method in class org.apache.blur.utils.RowDocumentUtil
 
getRowCount(String) - Method in class org.apache.blur.manager.indexserver.AbstractIndexServer
 
getRowCount(String) - Method in interface org.apache.blur.manager.IndexServer
Gets the row count of the table.
getRowCount() - Method in class org.apache.blur.manager.writer.BlurIndex
 
getRowFromMutations(String, List<RecordMutation>) - Static method in class org.apache.blur.thrift.MutationHelper
 
getSafemodePath(String) - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getSegmentCount() - Method in class org.apache.blur.manager.writer.BlurIndex
 
getSegmentReader(IndexReader) - Static method in class org.apache.blur.utils.BlurUtil
 
getSelectorThreads() - Method in class org.apache.blur.thrift.ThriftServer
 
getSequentialSubReaders(BaseCompositeReader<IndexReader>) - Static method in class org.apache.lucene.index.BaseCompositeReaderUtil
 
getServerContext() - Method in class org.apache.blur.server.FilteredBlurServer
 
getServerTransport() - Method in class org.apache.blur.thrift.ThriftServer
 
getShard(String, int) - Method in class org.apache.blur.manager.BlurPartitioner
Gets the shard from the the rowId, based on the number of shards in the table.
getShard(Text, int) - Method in class org.apache.blur.manager.BlurPartitioner
Gets the shard from the the rowId, based on the number of shards in the table.
getShard() - Method in class org.apache.blur.server.ShardContext
 
getShardContext() - Method in class org.apache.blur.manager.writer.BlurIndex
 
getShardIndex(String) - Static method in class org.apache.blur.utils.BlurUtil
 
getShardInfo() - Method in interface org.apache.blur.manager.results.BlurResultIterable
 
getShardInfo() - Method in class org.apache.blur.manager.results.BlurResultIterableClient
 
getShardInfo() - Method in class org.apache.blur.manager.results.BlurResultIterableMultiple
 
getShardInfo() - Method in class org.apache.blur.manager.results.BlurResultIterableSearcher
 
getShardInfo() - Method in class org.apache.blur.manager.results.BlurResultIterableSimple
 
getShardLayoutPath(String) - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getShardLayoutPathLocks(String) - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getShardList(String) - Method in class org.apache.blur.manager.indexserver.AbstractDistributedIndexServer
 
getShardList(String) - Method in interface org.apache.blur.manager.IndexServer
The shard list for a given table.
getShardList(String) - Method in class org.apache.blur.manager.indexserver.LocalIndexServer
 
getShardListCurrentServerOnly(String) - Method in class org.apache.blur.manager.indexserver.DistributedIndexServer
 
getShardListCurrentServerOnly(String) - Method in interface org.apache.blur.manager.IndexServer
Gets a sorted list of shards being served by this server.
getShardListCurrentServerOnly(String) - Method in class org.apache.blur.manager.indexserver.LocalIndexServer
 
getShardName(String, String, int, BlurPartitioner) - Static method in class org.apache.blur.thrift.MutationHelper
 
getShardName(int) - Static method in class org.apache.blur.utils.BlurUtil
 
getShardName(String, int) - Static method in class org.apache.blur.utils.BlurUtil
 
getShards() - Method in class org.apache.blur.manager.indexserver.DistributedLayoutManager
 
getShardServerContext() - Static method in class org.apache.blur.server.ShardServerContext
Gets the ShardServerContext for this Thread.
getShardServerList(String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
getShardServerList(String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
getShardState(String) - Method in class org.apache.blur.manager.indexserver.DistributedIndexServer
 
getShardState(String) - Method in interface org.apache.blur.manager.IndexServer
Get the shard state.
getShardState(String) - Method in class org.apache.blur.manager.indexserver.LocalIndexServer
 
getShardState(String) - Method in class org.apache.blur.manager.indexserver.ShardStateManager
 
getShutdown() - Method in class org.apache.blur.thrift.ThriftServer
 
getShutdownPath(String) - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getSimilarity() - Method in class org.apache.blur.server.TableContext
 
getSize() - Method in class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
 
getSnapshots() - Method in class org.apache.blur.manager.writer.BlurIndex
 
getSnapshots() - Method in class org.apache.blur.manager.writer.BlurIndexReadOnly
 
getSnapshots() - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
getSnapshots() - Method in class org.apache.blur.manager.writer.SnapshotIndexDeletionPolicy
 
getSnapshotsDirectoryPath() - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
getSnapshotsDirectoryPath() - Method in class org.apache.blur.manager.writer.SnapshotIndexDeletionPolicy
 
getStatusCleanupTimerDelay() - Method in class org.apache.blur.manager.status.QueryStatusManager
 
getSuccessfulResponseLogMessage(String, String, String, String, double, User) - Static method in class org.apache.blur.utils.BlurUtil
 
getSupportedFeatures() - Static method in class org.apache.blur.utils.RamUsageEstimator
Return the set of supported JVM features that improve the estimation.
getSystemBlurConfiguration() - Static method in class org.apache.blur.server.TableContext
 
getSystemConfiguration() - Static method in class org.apache.blur.server.TableContext
 
getTable() - Method in class org.apache.blur.manager.status.QueryStatus
 
getTable() - Method in class org.apache.blur.server.TableContext
 
getTable() - Method in class org.apache.blur.utils.QueryCacheKey
 
getTableContext() - Method in interface org.apache.blur.server.Configurable
 
getTableContext() - Method in class org.apache.blur.server.ShardContext
 
getTableDescriptor(boolean, String, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
getTableDescriptor(boolean, String, String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
getTableList(boolean) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
getTableList(boolean, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
getTableList(boolean, String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
getTablePath(String, String) - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getTablePath() - Method in class org.apache.blur.server.TableContext
 
getTableSize(String) - Method in class org.apache.blur.manager.indexserver.AbstractDistributedIndexServer
 
getTableSize(String) - Method in interface org.apache.blur.manager.IndexServer
Gets the current on disk table size.
getTableSize(String) - Method in class org.apache.blur.manager.indexserver.LocalIndexServer
 
getTablesPath(String) - Static method in class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 
getTimeBetweenCommits() - Method in class org.apache.blur.server.TableContext
 
getTimeBetweenRefreshs() - Method in class org.apache.blur.server.TableContext
 
getTimeBetweenWALSyncsNanos() - Method in class org.apache.blur.server.TableContext
 
getTNonblockingServerSocket(String, int) - Static method in class org.apache.blur.thrift.ThriftServer
 
getTotalResults() - Method in interface org.apache.blur.manager.results.BlurResultIterable
 
getTotalResults() - Method in class org.apache.blur.manager.results.BlurResultIterableClient
 
getTotalResults() - Method in class org.apache.blur.manager.results.BlurResultIterableMultiple
 
getTotalResults() - Method in class org.apache.blur.manager.results.BlurResultIterableSearcher
 
getTotalResults() - Method in class org.apache.blur.manager.results.BlurResultIterableSimple
 
getTraceIds() - Method in class org.apache.blur.trace.hdfs.HdfsTraceStorage
 
getTracer(String) - Method in class org.apache.blur.server.BlurServerContext
 
getTraceRequestId() - Method in class org.apache.blur.server.BlurServerContext
 
getTraceRootId() - Method in class org.apache.blur.server.BlurServerContext
 
getUnsupportedFeatures() - Static method in class org.apache.blur.utils.RamUsageEstimator
Return the set of unsupported JVM features that improve the estimation.
getUser() - Method in class org.apache.blur.server.BlurServerContext
 
getUserUuid() - Method in class org.apache.blur.manager.status.QueryStatus
 
getVersion() - Static method in class org.apache.blur.utils.BlurUtil
 
getWalShardPath() - Method in class org.apache.blur.server.ShardContext
 
getWalTablePath() - Method in class org.apache.blur.server.TableContext
 

H

hashCode() - Method in class org.apache.blur.utils.QueryCacheKey
 
hasNext() - Method in class org.apache.blur.manager.results.BlurResultIterableClient.SearchIterator
 
hasNext() - Method in class org.apache.blur.manager.results.BlurResultIterableMultiple.MultipleHitsIterator
 
hasNext() - Method in class org.apache.blur.manager.results.PeekableIterator
 
hasNext() - Method in class org.apache.blur.utils.IteratorConverter
 
HdfsTraceStorage - Class in org.apache.blur.trace.hdfs
 
HdfsTraceStorage(BlurConfiguration) - Constructor for class org.apache.blur.trace.hdfs.HdfsTraceStorage
 
highlight(int, Document, SegmentReader) - Method in class org.apache.blur.manager.BlurHighlighter
 
highlight(int, Document, Query, FieldManager, IndexReader, String, String) - Static method in class org.apache.blur.utils.HighlightHelper
NOTE: This method will not preserve the correct field types.
HighlightHelper - Class in org.apache.blur.utils
 
HighlightHelper() - Constructor for class org.apache.blur.utils.HighlightHelper
 
HITS_COMPARATOR - Static variable in class org.apache.blur.utils.BlurUtil
 
HITS_PEEKABLE_ITERATOR_COMPARATOR - Static variable in class org.apache.blur.utils.BlurUtil
 
humanizeTime(long, TimeUnit) - Static method in class org.apache.blur.utils.BlurUtil
 
humanizeTime(long, long, long) - Static method in class org.apache.blur.utils.BlurUtil
 
humanReadableUnits(long) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns size in human-readable units (GB, MB, KB or bytes).
humanReadableUnits(long, DecimalFormat) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns size in human-readable units (GB, MB, KB or bytes).
humanSizeOf(Object) - Static method in class org.apache.blur.utils.RamUsageEstimator
Return a human-readable size of a given object.

I

ID_TYPE - Static variable in class org.apache.blur.utils.RowDocumentUtil
 
ignoreExecutionException(Future<T>, T) - Static method in class org.apache.blur.utils.ForkJoin
 
include(String) - Method in interface org.apache.blur.utils.ClassNameFilter
 
IndexAction - Class in org.apache.blur.manager.writer
 
IndexAction() - Constructor for class org.apache.blur.manager.writer.IndexAction
 
IndexImporter - Class in org.apache.blur.manager.writer
 
IndexImporter(BlurIndex, ShardContext, TimeUnit, long) - Constructor for class org.apache.blur.manager.writer.IndexImporter
 
IndexManager - Class in org.apache.blur.manager
 
IndexManager(IndexServer, ClusterStatus, BlurFilterCache, int, int, int, int, long, int, DeepPagingCache) - Constructor for class org.apache.blur.manager.IndexManager
 
IndexSearcherClosable - Class in org.apache.blur.server
 
IndexSearcherClosable(IndexReader, ExecutorService) - Constructor for class org.apache.blur.server.IndexSearcherClosable
 
IndexServer - Interface in org.apache.blur.manager
The IndexServer interface provides the internal API to interact with the indexes being served in the shard server instance.
init() - Method in class org.apache.blur.manager.indexserver.DistributedLayoutManager
 
init() - Method in class org.apache.blur.manager.status.QueryStatusManager
 
init() - Method in class org.apache.blur.thrift.BlurControllerServer
 
init() - Method in class org.apache.blur.thrift.BlurShardServer
 
init(double) - Static method in class org.apache.blur.utils.GCWatcher
Initializes the GCWatcher to watch for any garbage collection that leaves more then the given ratio free.
init(double) - Static method in class org.apache.blur.utils.GCWatcherJdk6
 
init(double) - Static method in class org.apache.blur.utils.GCWatcherJdk7
 
intField(FieldInfo, int) - Method in class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
 
isClosed() - Method in class org.apache.blur.manager.writer.BlurIndex
 
isClosed() - Method in class org.apache.blur.manager.writer.BlurIndexReadOnly
 
isClosed() - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
isEmpty(String, String) - Static method in class org.apache.blur.thrift.ThriftServer
 
isEnabled(boolean, String, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
isEnabled(boolean, String, String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
isFinished() - Method in class org.apache.blur.manager.status.QueryStatus
 
isInSafeMode(boolean, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
isInSafeMode(boolean, String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
isInSafeMode(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
isInSafeMode(String) - Method in class org.apache.blur.thrift.TableAdmin
 
isOpen() - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
isOpen() - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
isReadOnly(boolean, String, String) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
isReadOnly(boolean, String, String) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
isSupportedJVM() - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns true, if the current JVM is fully supported by RamUsageEstimator.
isTableEnabled(boolean, String, String) - Method in class org.apache.blur.thrift.TableAdmin
 
isValid(QueryCacheEntry, SortedSet<String>) - Method in class org.apache.blur.utils.QueryCache
 
isValid(QueryCacheEntry) - Method in class org.apache.blur.utils.QueryCache
 
isValidForCleanUp() - Method in class org.apache.blur.manager.status.QueryStatus
 
isWritersWaiting() - Method in class org.apache.blur.manager.writer.IndexAction
 
IterableConverter<F,T,E extends Exception> - Class in org.apache.blur.utils
 
IterableConverter(BlurIterable<F, E>, Converter<F, T, E>) - Constructor for class org.apache.blur.utils.IterableConverter
 
iterator() - Method in class org.apache.blur.manager.results.BlurResultIterableClient
 
iterator() - Method in class org.apache.blur.manager.results.BlurResultIterableMultiple
 
iterator() - Method in class org.apache.blur.manager.results.BlurResultIterableSearcher
 
iterator() - Method in class org.apache.blur.manager.results.BlurResultIterableSimple
 
iterator() - Method in class org.apache.blur.utils.IterableConverter
 
iterator() - Method in class org.apache.blur.utils.ReferenceIterable
 
iterator() - Method in class org.apache.blur.utils.TermDocIterable
 
IteratorConverter<F,T,E extends Exception> - Class in org.apache.blur.utils
 
IteratorConverter(BlurIterator<F, E>, Converter<F, T, E>) - Constructor for class org.apache.blur.utils.IteratorConverter
 

J

JVM_INFO_STRING - Static variable in class org.apache.blur.utils.RamUsageEstimator
JVM info string for debugging and reports.

L

lastChanceErrorHandling(T, Class<T>) - Static method in class org.apache.blur.utils.BlurUtil
 
LayoutMissingException - Exception in org.apache.blur.manager.indexserver
 
LayoutMissingException() - Constructor for exception org.apache.blur.manager.indexserver.LayoutMissingException
 
LazyBlurResult - Class in org.apache.blur.manager.results
The LazyBlurResult adds a method to fetch the result with the client that was used to execute the query.
LazyBlurResult(BlurResult, Blur.Client) - Constructor for class org.apache.blur.manager.results.LazyBlurResult
 
level(int, int, Map<String, Integer>, Map<String, String>, String, Random) - Static method in class org.apache.blur.manager.indexserver.MasterBasedLeveler
 
listSnapshots(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
listSnapshots(String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
listSnapshots(String) - Method in class org.apache.blur.thrift.BlurShardServer
 
LocalIndexServer - Class in org.apache.blur.manager.indexserver
 
LocalIndexServer(TableDescriptor) - Constructor for class org.apache.blur.manager.indexserver.LocalIndexServer
 
LocalIndexServer(TableDescriptor, boolean) - Constructor for class org.apache.blur.manager.indexserver.LocalIndexServer
 
lockForSafeMode(ZooKeeper, String, String) - Static method in class org.apache.blur.utils.BlurUtil
 
log(Log) - Method in class org.apache.blur.utils.SimpleTimer
 
logging(String, Level) - Method in class org.apache.blur.server.FilteredBlurServer
 
logging(String, Level) - Method in class org.apache.blur.thrift.TableAdmin
 
longField(FieldInfo, long) - Method in class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
 

M

main(String[]) - Static method in class org.apache.blur.thrift.Shutdown
 
main(String[]) - Static method in class org.apache.blur.thrift.ThriftBlurControllerServer
 
main(String[]) - Static method in class org.apache.blur.thrift.ThriftBlurShardServer
 
main(String[]) - Static method in class org.apache.blur.utils.CreateGarbage
 
main(String[]) - Static method in class org.apache.blur.utils.TableShardCountCollapser
 
MasterBasedDistributedLayoutFactory - Class in org.apache.blur.manager.indexserver
 
MasterBasedDistributedLayoutFactory(ZooKeeper, String) - Constructor for class org.apache.blur.manager.indexserver.MasterBasedDistributedLayoutFactory
 
MasterBasedLeveler - Class in org.apache.blur.manager.indexserver
 
MasterBasedLeveler() - Constructor for class org.apache.blur.manager.indexserver.MasterBasedLeveler
 
MemoryReporter - Class in org.apache.blur.utils
 
merge(BlurExecutorCompletionService<BlurResultIterable>) - Method in class org.apache.blur.manager.results.MergerBlurResultIterable
 
merge(BlurExecutorCompletionService<TableStats>) - Method in class org.apache.blur.manager.stats.MergerTableStats
 
merge(BlurExecutorCompletionService<List<BlurQueryStatus>>) - Method in class org.apache.blur.manager.status.MergerQueryStatus
 
merge(BlurQueryStatus, BlurQueryStatus) - Static method in class org.apache.blur.manager.status.MergerQueryStatus
 
merge(BlurExecutorCompletionService<BlurQueryStatus>) - Method in class org.apache.blur.manager.status.MergerQueryStatusSingle
 
merge(Schema, Schema) - Static method in class org.apache.blur.thrift.BlurControllerServer
 
merge(BlurExecutorCompletionService<OUTPUT>) - Method in interface org.apache.blur.utils.ForkJoin.Merger
 
merge(ForkJoin.Merger<OUTPUT>) - Method in interface org.apache.blur.utils.ForkJoin.ParallelReturn
 
MergerBlurResultIterable - Class in org.apache.blur.manager.results
 
MergerBlurResultIterable(BlurQuery) - Constructor for class org.apache.blur.manager.results.MergerBlurResultIterable
 
MergerQueryStatus - Class in org.apache.blur.manager.status
 
MergerQueryStatus(long) - Constructor for class org.apache.blur.manager.status.MergerQueryStatus
 
MergerQueryStatusSingle - Class in org.apache.blur.manager.status
 
MergerQueryStatusSingle(long) - Constructor for class org.apache.blur.manager.status.MergerQueryStatusSingle
 
MergerTableStats - Class in org.apache.blur.manager.stats
 
MergerTableStats(long) - Constructor for class org.apache.blur.manager.stats.MergerTableStats
 
metrics(Set<String>) - Method in class org.apache.blur.server.FilteredBlurServer
 
metrics(Set<String>) - Method in class org.apache.blur.thrift.TableAdmin
 
MutatableAction - Class in org.apache.blur.manager.writer
 
MutatableAction(ShardContext) - Constructor for class org.apache.blur.manager.writer.MutatableAction
 
mutate(RowMutation) - Method in class org.apache.blur.manager.IndexManager
 
mutate(List<RowMutation>) - Method in class org.apache.blur.manager.IndexManager
 
mutate(RowMutation) - Method in class org.apache.blur.manager.writer.MutatableAction
 
mutate(List<RowMutation>) - Method in class org.apache.blur.manager.writer.MutatableAction
 
mutate(RowMutation) - Method in class org.apache.blur.server.FilteredBlurServer
 
mutate(RowMutation) - Method in class org.apache.blur.thrift.BlurControllerServer
 
mutate(RowMutation) - Method in class org.apache.blur.thrift.BlurShardServer
 
mutateBatch(List<RowMutation>) - Method in class org.apache.blur.server.FilteredBlurServer
 
mutateBatch(List<RowMutation>) - Method in class org.apache.blur.thrift.BlurControllerServer
 
mutateBatch(List<RowMutation>) - Method in class org.apache.blur.thrift.BlurShardServer
 
MutationHelper - Class in org.apache.blur.thrift
 
MutationHelper() - Constructor for class org.apache.blur.thrift.MutationHelper
 
MutationQueue - Class in org.apache.blur.manager.writer
 
MutationQueue() - Constructor for class org.apache.blur.manager.writer.MutationQueue
 
MutationQueueProcessor - Class in org.apache.blur.manager.writer
 
MutationQueueProcessor(BlockingQueue<RowMutation>, BlurIndex, ShardContext, AtomicInteger) - Constructor for class org.apache.blur.manager.writer.MutationQueueProcessor
 

N

needsField(FieldInfo) - Method in class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
 
newInstanceBlurIndex(ShardContext, Directory, SharedMergeScheduler, ExecutorService, BlurIndexCloser, BlurIndexWarmup) - Method in class org.apache.blur.server.TableContext
 
newQueryStatus(String, BlurQuery, int, AtomicBoolean, User) - Method in class org.apache.blur.manager.status.QueryStatusManager
 
next() - Method in class org.apache.blur.manager.results.BlurResultIterableClient.SearchIterator
 
next() - Method in class org.apache.blur.manager.results.BlurResultIterableMultiple.MultipleHitsIterator
 
next() - Method in class org.apache.blur.manager.results.PeekableIterator
 
next() - Method in class org.apache.blur.utils.IteratorConverter
 
NOT_FOUND - Static variable in class org.apache.blur.manager.IndexManager
 
nullCheck(T, String) - Static method in class org.apache.blur.utils.BlurUtil
 
NUM_BYTES_ARRAY_HEADER - Static variable in class org.apache.blur.utils.RamUsageEstimator
Number of bytes to represent an array header (no content, but with alignments).
NUM_BYTES_BOOLEAN - Static variable in class org.apache.blur.utils.RamUsageEstimator
 
NUM_BYTES_BYTE - Static variable in class org.apache.blur.utils.RamUsageEstimator
 
NUM_BYTES_CHAR - Static variable in class org.apache.blur.utils.RamUsageEstimator
 
NUM_BYTES_DOUBLE - Static variable in class org.apache.blur.utils.RamUsageEstimator
 
NUM_BYTES_FLOAT - Static variable in class org.apache.blur.utils.RamUsageEstimator
 
NUM_BYTES_INT - Static variable in class org.apache.blur.utils.RamUsageEstimator
 
NUM_BYTES_LONG - Static variable in class org.apache.blur.utils.RamUsageEstimator
 
NUM_BYTES_OBJECT_ALIGNMENT - Static variable in class org.apache.blur.utils.RamUsageEstimator
A constant specifying the object alignment boundary inside the JVM.
NUM_BYTES_OBJECT_HEADER - Static variable in class org.apache.blur.utils.RamUsageEstimator
Number of bytes to represent an object header (no fields, no alignments).
NUM_BYTES_OBJECT_REF - Static variable in class org.apache.blur.utils.RamUsageEstimator
Number of bytes this jvm uses to represent an object reference.
NUM_BYTES_SHORT - Static variable in class org.apache.blur.utils.RamUsageEstimator
 

O

onCommit(List<? extends IndexCommit>) - Method in class org.apache.blur.manager.writer.SnapshotIndexDeletionPolicy
 
ONE_GB - Static variable in class org.apache.blur.utils.RamUsageEstimator
One gigabyte bytes.
ONE_KB - Static variable in class org.apache.blur.utils.RamUsageEstimator
One kilobyte bytes.
ONE_MB - Static variable in class org.apache.blur.utils.RamUsageEstimator
One megabyte bytes.
onEviction(QueryCacheKey, QueryCacheEntry) - Method in class org.apache.blur.utils.QueryCache
 
onInit(List<? extends IndexCommit>) - Method in class org.apache.blur.manager.writer.SnapshotIndexDeletionPolicy
 
open(String, String) - Method in class org.apache.blur.manager.indexserver.ShardStateManager
 
opening(String, String, BlurIndex) - Method in class org.apache.blur.manager.AliasBlurFilterCache
 
opening(String, String, BlurIndex) - Method in class org.apache.blur.manager.BlurFilterCache
Notifies the cache that the index is opening on this shard server.
opening(String, String, BlurIndex) - Method in class org.apache.blur.manager.DefaultBlurFilterCache
 
opening(String, String) - Method in class org.apache.blur.manager.indexserver.ShardStateManager
 
openingError(String, String) - Method in class org.apache.blur.manager.indexserver.ShardStateManager
 
optimize(String, int) - Method in class org.apache.blur.manager.IndexManager
 
optimize(int) - Method in class org.apache.blur.manager.writer.BlurIndex
 
optimize(int) - Method in class org.apache.blur.manager.writer.BlurIndexReadOnly
 
optimize(int) - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
optimize(String, int) - Method in class org.apache.blur.server.FilteredBlurServer
 
optimize(String, int) - Method in class org.apache.blur.thrift.BlurControllerServer
 
optimize(String, int) - Method in class org.apache.blur.thrift.BlurShardServer
 
org.apache.blur.manager - package org.apache.blur.manager
 
org.apache.blur.manager.clusterstatus - package org.apache.blur.manager.clusterstatus
 
org.apache.blur.manager.indexserver - package org.apache.blur.manager.indexserver
 
org.apache.blur.manager.results - package org.apache.blur.manager.results
 
org.apache.blur.manager.stats - package org.apache.blur.manager.stats
 
org.apache.blur.manager.status - package org.apache.blur.manager.status
 
org.apache.blur.manager.writer - package org.apache.blur.manager.writer
 
org.apache.blur.server - package org.apache.blur.server
 
org.apache.blur.server.example - package org.apache.blur.server.example
 
org.apache.blur.thrift - package org.apache.blur.thrift
 
org.apache.blur.trace.hdfs - package org.apache.blur.trace.hdfs
 
org.apache.blur.utils - package org.apache.blur.utils
 
org.apache.lucene.index - package org.apache.lucene.index
 

P

parse(String) - Method in interface org.apache.blur.manager.BlurFilterCache.FilterParser
 
parseFilter(String, String, boolean, FieldManager, BlurFilterCache, TableContext) - Static method in class org.apache.blur.manager.QueryParserUtil
 
parseQuery(String, Query) - Method in class org.apache.blur.manager.IndexManager
 
parseQuery(String, boolean, FieldManager, Filter, Filter, ScoreType, TableContext) - Static method in class org.apache.blur.manager.QueryParserUtil
 
parseQuery(String, Query) - Method in class org.apache.blur.server.FilteredBlurServer
 
parseQuery(String, Query) - Method in class org.apache.blur.thrift.BlurControllerServer
 
parseQuery(String, Query) - Method in class org.apache.blur.thrift.BlurShardServer
 
peek() - Method in class org.apache.blur.manager.results.PeekableIterator
Only valid is hasNext is true.
PeekableIterator<T,E extends Exception> - Class in org.apache.blur.manager.results
 
performMutate(IndexSearcherClosable, IndexWriter) - Method in class org.apache.blur.manager.writer.IndexAction
 
performMutate(IndexSearcherClosable, IndexWriter) - Method in class org.apache.blur.manager.writer.MutatableAction
 
ping() - Method in class org.apache.blur.server.FilteredBlurServer
 
ping() - Method in class org.apache.blur.thrift.TableAdmin
 
poll() - Method in class org.apache.blur.utils.BlurExecutorCompletionService
 
poll(long, TimeUnit) - Method in class org.apache.blur.utils.BlurExecutorCompletionService
 
poll(long, TimeUnit, boolean, Object...) - Method in class org.apache.blur.utils.BlurExecutorCompletionService
 
populateSelector(IndexSearcherClosable, String, String, Selector) - Static method in class org.apache.blur.manager.IndexManager
 
preServe() - Method in class org.apache.blur.server.ControllerServerEventHandler
 
preServe() - Method in class org.apache.blur.server.ShardServerEventHandler
 
PRIME_DOC_TERM - Static variable in class org.apache.blur.utils.BlurUtil
 
printUlimits() - Static method in class org.apache.blur.thrift.ThriftServer
 
process(WatchedEvent) - Method in class org.apache.blur.manager.indexserver.BlurServerShutDown
 
process(IndexAction) - Method in class org.apache.blur.manager.writer.BlurIndex
 
process(IndexAction) - Method in class org.apache.blur.manager.writer.BlurIndexReadOnly
 
process(IndexAction) - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
processContext(ServerContext, TTransport, TTransport) - Method in class org.apache.blur.server.ControllerServerEventHandler
 
processContext(ServerContext, TTransport, TTransport) - Method in class org.apache.blur.server.ShardServerEventHandler
 
processCounter(MetricName, Counter, ConcurrentMap<String, Metric>) - Method in class org.apache.blur.utils.MemoryReporter
 
processGauge(MetricName, Gauge<?>, ConcurrentMap<String, Metric>) - Method in class org.apache.blur.utils.MemoryReporter
 
processHistogram(MetricName, Histogram, ConcurrentMap<String, Metric>) - Method in class org.apache.blur.utils.MemoryReporter
 
processMeter(MetricName, Metered, ConcurrentMap<String, Metric>) - Method in class org.apache.blur.utils.MemoryReporter
 
processTimer(MetricName, Timer, ConcurrentMap<String, Metric>) - Method in class org.apache.blur.utils.MemoryReporter
 
put(List<RowMutation>) - Method in class org.apache.blur.manager.writer.MutationQueue
 
put(QueryCacheKey, QueryCacheEntry) - Method in class org.apache.blur.utils.QueryCache
 

Q

query(String, BlurQuery, AtomicLongArray) - Method in class org.apache.blur.manager.IndexManager
 
query(String, BlurQuery) - Method in class org.apache.blur.server.FilteredBlurServer
 
query(String, BlurQuery) - Method in class org.apache.blur.thrift.BlurControllerServer
 
query(String, BlurQuery) - Method in class org.apache.blur.thrift.BlurShardServer
 
QueryCache - Class in org.apache.blur.utils
 
QueryCache(String, int, long) - Constructor for class org.apache.blur.utils.QueryCache
 
QueryCacheEntry - Class in org.apache.blur.utils
 
QueryCacheEntry(BlurResults) - Constructor for class org.apache.blur.utils.QueryCacheEntry
 
QueryCacheKey - Class in org.apache.blur.utils
 
QueryCacheKey(String, BlurQuery) - Constructor for class org.apache.blur.utils.QueryCacheKey
 
QueryParserUtil - Class in org.apache.blur.manager
 
QueryParserUtil() - Constructor for class org.apache.blur.manager.QueryParserUtil
 
queryStatus(String, String) - Method in class org.apache.blur.manager.IndexManager
 
QueryStatus - Class in org.apache.blur.manager.status
This class is accessed by multiple threads (one for each shard) executing the query.
QueryStatus(long, String, BlurQuery, AtomicBoolean, User) - Constructor for class org.apache.blur.manager.status.QueryStatus
 
queryStatus(String, String) - Method in class org.apache.blur.manager.status.QueryStatusManager
 
queryStatusById(String, String) - Method in class org.apache.blur.server.FilteredBlurServer
 
queryStatusById(String, String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
queryStatusById(String, String) - Method in class org.apache.blur.thrift.BlurShardServer
 
queryStatusIdList(String) - Method in class org.apache.blur.manager.IndexManager
 
queryStatusIdList(String) - Method in class org.apache.blur.manager.status.QueryStatusManager
 
queryStatusIdList(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
queryStatusIdList(String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
queryStatusIdList(String) - Method in class org.apache.blur.thrift.BlurShardServer
 
QueryStatusManager - Class in org.apache.blur.manager.status
 
QueryStatusManager() - Constructor for class org.apache.blur.manager.status.QueryStatusManager
 
quietClose(Object...) - Static method in class org.apache.blur.utils.BlurUtil
 

R

RamUsageEstimator - Class in org.apache.blur.utils
Estimates the size (memory representation) of Java objects.
RamUsageEstimator.JvmFeature - Enum in org.apache.blur.utils
JVM diagnostic features.
read(TBase<?, ?>) - Static method in class org.apache.blur.utils.BlurUtil
 
readCurrentLayout(String) - Method in interface org.apache.blur.manager.indexserver.DistributedLayoutFactory
 
readCurrentLayout(String) - Method in class org.apache.blur.manager.indexserver.MasterBasedDistributedLayoutFactory
 
readerBase(BaseCompositeReader<IndexReader>, int) - Static method in class org.apache.lucene.index.BaseCompositeReaderUtil
 
ReaderBlurRecord - Interface in org.apache.blur.utils
 
readerIndex(BaseCompositeReader<IndexReader>, int) - Static method in class org.apache.lucene.index.BaseCompositeReaderUtil
 
ReadInterceptor - Class in org.apache.blur.manager
 
ReadInterceptor(BlurConfiguration) - Constructor for class org.apache.blur.manager.ReadInterceptor
 
readRecord(Document, ReaderBlurRecord) - Static method in class org.apache.blur.utils.RowDocumentUtil
 
recordFrequency(String, String, String, String) - Method in class org.apache.blur.manager.IndexManager
 
recordFrequency(IndexReader, String, String, String) - Static method in class org.apache.blur.manager.IndexManager
 
recordFrequency(String, String, String, String) - Method in class org.apache.blur.server.FilteredBlurServer
 
recordFrequency(String, String, String, String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
recordFrequency(String, String, String, String) - Method in class org.apache.blur.thrift.BlurShardServer
 
recordMethodCallsAndAverageTimes(T, Class<T>, boolean) - Static method in class org.apache.blur.utils.BlurUtil
 
reduceMutates(List<RowMutation>) - Static method in class org.apache.blur.manager.writer.MutatableAction
 
ReferenceIterable<T> - Class in org.apache.blur.utils
 
ReferenceIterable(T) - Constructor for class org.apache.blur.utils.ReferenceIterable
 
refresh() - Method in class org.apache.blur.manager.writer.BlurIndex
 
refresh() - Method in class org.apache.blur.manager.writer.BlurIndexReadOnly
 
refresh() - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
register(BlurServerShutDown.BlurShutdown, ZooKeeper) - Method in class org.apache.blur.manager.indexserver.BlurServerShutDown
 
register(BlurIndex) - Method in class org.apache.blur.manager.writer.BlurIndexRefresher
 
registerAction(GCAction) - Static method in class org.apache.blur.utils.GCWatcher
Registers an GCAction to be taken when the JVM is near an OutOfMemoryError condition.
registerAction(GCAction) - Static method in class org.apache.blur.utils.GCWatcherJdk6
 
registerAction(GCAction) - Static method in class org.apache.blur.utils.GCWatcherJdk7
 
registerActionOnTableStateChange(ClusterStatus.Action) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
registerActionOnTableStateChange(ClusterStatus.Action) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
registerContextForCall(ControllerServerContext) - Static method in class org.apache.blur.server.ControllerServerContext
Registers the ControllerServerContext for this thread.
registerContextForCall(ShardServerContext) - Static method in class org.apache.blur.server.ShardServerContext
Registers the ShardServerContext for this thread.
registerNode(String, byte[]) - Method in class org.apache.blur.manager.indexserver.SafeMode
 
release() - Method in interface org.apache.blur.manager.indexserver.DistributedIndexServer.ReleaseReader
 
remove(QueryCacheKey) - Method in class org.apache.blur.utils.QueryCache
 
removeAll(ZooKeeper, String) - Static method in class org.apache.blur.utils.BlurUtil
 
removeIndexFiles(String) - Static method in class org.apache.blur.utils.BlurUtil
 
removeSnapshot(String) - Method in class org.apache.blur.manager.writer.BlurIndex
 
removeSnapshot(String) - Method in class org.apache.blur.manager.writer.BlurIndexReadOnly
 
removeSnapshot(String) - Method in class org.apache.blur.manager.writer.BlurIndexSimpleWriter
 
removeSnapshot(String, String) - Method in class org.apache.blur.manager.writer.SnapshotIndexDeletionPolicy
 
removeSnapshot(String, String) - Method in class org.apache.blur.server.FilteredBlurServer
 
removeSnapshot(String, String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
removeSnapshot(String, String) - Method in class org.apache.blur.thrift.BlurShardServer
 
removeStatus(QueryStatus) - Method in class org.apache.blur.manager.status.QueryStatusManager
 
removeTable(String, String, boolean) - Method in class org.apache.blur.manager.clusterstatus.ClusterStatus
 
removeTable(String, String, boolean) - Method in class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
removeTable(String, boolean) - Method in class org.apache.blur.server.example.DisableTableAdminServer
 
removeTable(String, boolean) - Method in class org.apache.blur.server.FilteredBlurServer
 
removeTable(String, boolean) - Method in class org.apache.blur.thrift.TableAdmin
 
removeTrace(String) - Method in class org.apache.blur.trace.hdfs.HdfsTraceStorage
 
replaceColumns(String, Record) - Method in class org.apache.blur.manager.writer.MutatableAction
 
replaceRecord(String, Record) - Method in class org.apache.blur.manager.writer.MutatableAction
 
replaceRow(Row) - Method in class org.apache.blur.manager.writer.MutatableAction
 
reset() - Method in class org.apache.blur.server.ShardServerContext
Resets the ShardServerContext by closing the searchers.
reset() - Method in class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
 
ResetableDocumentStoredFieldVisitor - Class in org.apache.blur.utils
A StoredFieldVisitor that creates a Document containing all stored fields, or only specific requested fields provided to #DocumentStoredFieldVisitor(Set).
ResetableDocumentStoredFieldVisitor(Set<String>) - Constructor for class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
Load only fields named in the provided Set<String>.
ResetableDocumentStoredFieldVisitor(String...) - Constructor for class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
Load only fields named in the provided Set<String>.
ResetableDocumentStoredFieldVisitor() - Constructor for class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
Load all stored fields.
resetLogging() - Method in class org.apache.blur.server.FilteredBlurServer
 
resetLogging() - Method in class org.apache.blur.thrift.TableAdmin
 
resetSearchers() - Static method in class org.apache.blur.server.ShardServerContext
Resets the context, this closes and releases the index readers.
resetTraceIds() - Method in class org.apache.blur.server.BlurServerContext
 
results - Variable in class org.apache.blur.utils.QueryCacheEntry
 
RowDocumentUtil - Class in org.apache.blur.utils
 
RowDocumentUtil() - Constructor for class org.apache.blur.utils.RowDocumentUtil
 
run() - Method in class org.apache.blur.manager.writer.BlurIndexCloser
 
run() - Method in class org.apache.blur.manager.writer.BlurIndexRefresher
 
run() - Method in class org.apache.blur.manager.writer.IndexImporter
 
run() - Method in class org.apache.blur.manager.writer.MutationQueueProcessor
 
run() - Method in class org.apache.blur.manager.writer.SharedMergeScheduler
 
run() - Method in class org.apache.blur.utils.GCWatcherJdk6
 
run() - Method in class org.apache.blur.utils.MemoryReporter
 
run(String[]) - Method in class org.apache.blur.utils.TableShardCountCollapser
 
runTrace(Blur.Iface, boolean) - Static method in class org.apache.blur.utils.BlurUtil
 
runWithUser(Blur.Iface, boolean) - Static method in class org.apache.blur.utils.BlurUtil
 

S

SafeMode - Class in org.apache.blur.manager.indexserver
This class controls the startup of the cluster.
SafeMode(ZooKeeper, String, String, TimeUnit, long, TimeUnit, long, int) - Constructor for class org.apache.blur.manager.indexserver.SafeMode
 
schema(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
schema(String) - Method in class org.apache.blur.thrift.BlurShardServer
 
schema(String) - Method in class org.apache.blur.thrift.TableAdmin
 
setAcceptQueueSizePerThread(int) - Method in class org.apache.blur.thrift.ThriftServer
 
setClient(BlurControllerServer.BlurClient) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setClusterStatus(ClusterStatus) - Method in class org.apache.blur.thrift.TableAdmin
 
setConfiguration(BlurConfiguration) - Method in class org.apache.blur.thrift.TableAdmin
 
setDataFetchThreadCount(int) - Method in class org.apache.blur.thrift.BlurShardServer
 
setDefaultDelay(long) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setDelay(long) - Method in class org.apache.blur.manager.writer.BlurIndexRefresher
 
setDirectory(Directory) - Method in class org.apache.blur.server.ShardContext
 
setEventHandler(TServerEventHandler) - Method in class org.apache.blur.thrift.ThriftServer
 
setFamilyStr(String) - Method in class org.apache.blur.utils.BlurThriftRecord
 
setFamilyStr(String) - Method in interface org.apache.blur.utils.ReaderBlurRecord
 
setFetchDelay(long) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setFinished(boolean) - Method in class org.apache.blur.manager.status.QueryStatus
 
setHdfsDirPath(Path) - Method in class org.apache.blur.server.ShardContext
 
setIface(Blur.Iface) - Method in class org.apache.blur.thrift.ThriftServer
 
setIndexManager(IndexManager) - Method in class org.apache.blur.thrift.BlurShardServer
 
setIndexSearcherClosable(String, String, IndexSearcherClosable) - Method in class org.apache.blur.server.ShardServerContext
Sets the index searcher for this ShardServerContext for the given table and shard.
setIndexServer(IndexServer) - Method in class org.apache.blur.thrift.BlurShardServer
 
setMaxDefaultDelay(long) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setMaxDefaultRetries(int) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setMaxFetchDelay(long) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setMaxFetchRetries(int) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setMaxFrameSize(int) - Method in class org.apache.blur.thrift.ThriftServer
 
setMaxMutateDelay(long) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setMaxMutateRetries(int) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setMaxQueryCacheElements(int) - Method in class org.apache.blur.thrift.BlurShardServer
 
setMaxReadBufferBytes(long) - Method in class org.apache.blur.thrift.ThriftServer
 
setMaxRecordsPerRowFetchRequest(int) - Method in class org.apache.blur.thrift.TableAdmin
 
setMaxTimeToLive(long) - Method in class org.apache.blur.thrift.BlurShardServer
 
setMutateDelay(long) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setNodeName(String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setNodeName(String) - Method in class org.apache.blur.thrift.ThriftServer
 
setNodes(Collection<String>) - Method in class org.apache.blur.manager.indexserver.DistributedLayoutManager
 
setNodesOffline(Collection<String>) - Method in class org.apache.blur.manager.indexserver.DistributedLayoutManager
 
setPeriod(long) - Method in class org.apache.blur.manager.writer.BlurIndexRefresher
 
setQuery(BlurQuery) - Method in class org.apache.blur.utils.QueryCacheKey
 
setQueryChecker(BlurQueryChecker) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setQueryChecker(BlurQueryChecker) - Method in class org.apache.blur.thrift.BlurShardServer
 
setRecordIdStr(String) - Method in class org.apache.blur.utils.BlurThriftRecord
 
setRecordIdStr(String) - Method in interface org.apache.blur.utils.ReaderBlurRecord
 
setRemoteFetchCount(int) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setRowIdStr(String) - Method in class org.apache.blur.utils.BlurThriftRecord
 
setRowIdStr(String) - Method in interface org.apache.blur.utils.ReaderBlurRecord
 
setSelectorThreads(int) - Method in class org.apache.blur.thrift.ThriftServer
 
setServerTransport(TNonblockingServerSocket) - Method in class org.apache.blur.thrift.ThriftServer
 
setShard(String) - Method in class org.apache.blur.server.ShardContext
 
setShards(Collection<String>) - Method in class org.apache.blur.manager.indexserver.DistributedLayoutManager
 
setShutdown(BlurServerShutDown.BlurShutdown) - Method in class org.apache.blur.thrift.ThriftServer
 
setStartTime(BlurQuery) - Static method in class org.apache.blur.utils.BlurUtil
 
setStatusCleanupTimerDelay(long) - Method in class org.apache.blur.manager.status.QueryStatusManager
 
setSystemBlurConfiguration(BlurConfiguration) - Static method in class org.apache.blur.server.TableContext
 
setSystemConfiguration(Configuration) - Static method in class org.apache.blur.server.TableContext
 
setTable(String) - Method in class org.apache.blur.utils.QueryCacheKey
 
setTableContext(TableContext) - Method in interface org.apache.blur.server.Configurable
 
setTableContext(TableContext) - Method in class org.apache.blur.server.ShardContext
 
setTablePath(Path) - Method in class org.apache.blur.utils.TableShardCountCollapser
 
setThreadCount(int) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setThreadCount(int) - Method in class org.apache.blur.thrift.ThriftServer
 
setTraceRequestId(String) - Method in class org.apache.blur.server.BlurServerContext
 
setTraceRootId(String) - Method in class org.apache.blur.server.BlurServerContext
 
SETUP - Static variable in class org.apache.blur.manager.indexserver.SafeMode
 
setupFileSystem(String, int) - Static method in class org.apache.blur.utils.BlurUtil
 
setupJvmMetrics() - Static method in class org.apache.blur.thrift.ThriftServer
 
setupTraceStorage(BlurConfiguration) - Static method in class org.apache.blur.thrift.ThriftServer
 
setupZookeeper(ZooKeeper) - Static method in class org.apache.blur.utils.BlurUtil
 
setupZookeeper(ZooKeeper, String) - Static method in class org.apache.blur.utils.BlurUtil
 
setUser(User) - Method in class org.apache.blur.server.BlurServerContext
 
setUser(User) - Method in class org.apache.blur.server.FilteredBlurServer
 
setUser(User) - Method in class org.apache.blur.thrift.BlurControllerServer
 
setUser(User) - Method in class org.apache.blur.thrift.BlurShardServer
 
setWalShardPath(Path) - Method in class org.apache.blur.server.ShardContext
 
setWritesWaiting(AtomicInteger) - Method in class org.apache.blur.manager.writer.IndexAction
 
setZookeeper(ZooKeeper) - Method in class org.apache.blur.thrift.TableAdmin
 
shallowSizeOf(Object) - Static method in class org.apache.blur.utils.RamUsageEstimator
Estimates a "shallow" memory usage of the given object.
shallowSizeOfInstance(Class<?>) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns the shallow instance size in bytes an instance of the given class would occupy.
shardClusterList() - Method in class org.apache.blur.server.FilteredBlurServer
 
shardClusterList() - Method in class org.apache.blur.thrift.TableAdmin
 
ShardContext - Class in org.apache.blur.server
 
shards - Variable in class org.apache.blur.utils.QueryCacheEntry
 
ShardServerContext - Class in org.apache.blur.server
The thrift session that will hold index reader references to maintain across query and fetch calls.
ShardServerContext(SocketAddress, SocketAddress) - Constructor for class org.apache.blur.server.ShardServerContext
 
ShardServerEventHandler - Class in org.apache.blur.server
ShardServerContext is the session manager for the shard servers.
ShardServerEventHandler() - Constructor for class org.apache.blur.server.ShardServerEventHandler
 
shardServerLayout(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
shardServerLayout(String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
shardServerLayout(String) - Method in class org.apache.blur.thrift.BlurShardServer
 
shardServerLayoutState(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
shardServerLayoutState(String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
shardServerLayoutState(String) - Method in class org.apache.blur.thrift.BlurShardServer
 
shardServerList(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
shardServerList(String) - Method in class org.apache.blur.thrift.TableAdmin
 
ShardStateManager - Class in org.apache.blur.manager.indexserver
This class holds the current state of any given shard within the shard server.
ShardStateManager() - Constructor for class org.apache.blur.manager.indexserver.ShardStateManager
 
SharedMergeScheduler - Class in org.apache.blur.manager.writer
 
SharedMergeScheduler(int) - Constructor for class org.apache.blur.manager.writer.SharedMergeScheduler
 
shouldHighlight() - Method in class org.apache.blur.manager.BlurHighlighter
 
shouldNumberBeHighlighted(String, Number, Query) - Static method in class org.apache.blur.utils.HighlightHelper
 
shutdown() - Method in interface org.apache.blur.manager.indexserver.BlurServerShutDown.BlurShutdown
 
Shutdown - Class in org.apache.blur.thrift
 
Shutdown() - Constructor for class org.apache.blur.thrift.Shutdown
 
shutdown() - Static method in class org.apache.blur.utils.GCWatcher
Shuts down any internal threads watching the JVM.
shutdown() - Static method in class org.apache.blur.utils.GCWatcherJdk6
 
shutdown() - Static method in class org.apache.blur.utils.GCWatcherJdk7
 
SimpleTimer - Class in org.apache.blur.utils
 
SimpleTimer() - Constructor for class org.apache.blur.utils.SimpleTimer
 
sizeOf(byte[]) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns the size in bytes of the byte[] object.
sizeOf(boolean[]) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns the size in bytes of the boolean[] object.
sizeOf(char[]) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns the size in bytes of the char[] object.
sizeOf(short[]) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns the size in bytes of the short[] object.
sizeOf(int[]) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns the size in bytes of the int[] object.
sizeOf(float[]) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns the size in bytes of the float[] object.
sizeOf(long[]) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns the size in bytes of the long[] object.
sizeOf(double[]) - Static method in class org.apache.blur.utils.RamUsageEstimator
Returns the size in bytes of the double[] object.
sizeOf(Object) - Static method in class org.apache.blur.utils.RamUsageEstimator
Estimates the RAM usage by the given object.
sizeOf(Object, ClassNameFilter) - Static method in class org.apache.blur.utils.RamUsageEstimator
 
skipTo(long) - Method in interface org.apache.blur.manager.results.BlurResultIterable
 
skipTo(long) - Method in class org.apache.blur.manager.results.BlurResultIterableClient
 
skipTo(long) - Method in class org.apache.blur.manager.results.BlurResultIterableMultiple
 
skipTo(long) - Method in class org.apache.blur.manager.results.BlurResultIterableSearcher
 
skipTo(long) - Method in class org.apache.blur.manager.results.BlurResultIterableSimple
 
SnapshotIndexDeletionPolicy - Class in org.apache.blur.manager.writer
 
SnapshotIndexDeletionPolicy(Configuration, Path) - Constructor for class org.apache.blur.manager.writer.SnapshotIndexDeletionPolicy
 
SORT_FIELD_COMPARATOR - Static variable in class org.apache.blur.utils.BlurUtil
 
start() - Method in class org.apache.blur.thrift.ThriftServer
 
start(String) - Method in class org.apache.blur.utils.SimpleTimer
 
startIfNotRunning() - Method in class org.apache.blur.manager.writer.MutationQueueProcessor
 
startTrace(String, String) - Method in class org.apache.blur.server.FilteredBlurServer
 
startTrace(String, String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
startTrace(String, String) - Method in class org.apache.blur.thrift.BlurShardServer
 
STARTUP - Static variable in class org.apache.blur.manager.indexserver.SafeMode
 
stop(String) - Method in class org.apache.blur.utils.SimpleTimer
 
stopAllQueriesForBackPressure() - Method in class org.apache.blur.manager.status.QueryStatusManager
 
stopQueryForBackPressure() - Method in class org.apache.blur.manager.status.QueryStatus
 
store(TraceCollector) - Method in class org.apache.blur.trace.hdfs.HdfsTraceStorage
 
storeJson(Path, JSONObject) - Method in class org.apache.blur.trace.hdfs.HdfsTraceStorage
 
storePostFilter(String, String, Filter, BlurFilterCache.FilterParser) - Method in class org.apache.blur.manager.AliasBlurFilterCache
 
storePostFilter(String, String, Filter, BlurFilterCache.FilterParser) - Method in class org.apache.blur.manager.BlurFilterCache
The storePreFilter method stores the parsed post Filter (or Row Filter) for caching, and should return the Filter to be executed.
storePostFilter(String, String, Filter, BlurFilterCache.FilterParser) - Method in class org.apache.blur.manager.DefaultBlurFilterCache
 
storePreFilter(String, String, Filter, BlurFilterCache.FilterParser) - Method in class org.apache.blur.manager.AliasBlurFilterCache
 
storePreFilter(String, String, Filter, BlurFilterCache.FilterParser) - Method in class org.apache.blur.manager.BlurFilterCache
The storePreFilter method stores the parsed pre Filter (or Record Filter) for caching, and should return the Filter to be executed.
storePreFilter(String, String, Filter, BlurFilterCache.FilterParser) - Method in class org.apache.blur.manager.DefaultBlurFilterCache
 
stringField(FieldInfo, String) - Method in class org.apache.blur.utils.ResetableDocumentStoredFieldVisitor
 
submit(Callable<T>) - Method in class org.apache.blur.utils.BlurExecutorCompletionService
 
submit(Runnable, T) - Method in class org.apache.blur.utils.BlurExecutorCompletionService
 

T

TableAdmin - Class in org.apache.blur.thrift
 
TableAdmin() - Constructor for class org.apache.blur.thrift.TableAdmin
 
TableContext - Class in org.apache.blur.server
 
tableExists(boolean, String, String) - Method in class org.apache.blur.thrift.TableAdmin
 
tableList() - Method in class org.apache.blur.server.FilteredBlurServer
 
tableList() - Method in class org.apache.blur.thrift.TableAdmin
 
tableListByCluster(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
tableListByCluster(String) - Method in class org.apache.blur.thrift.TableAdmin
 
TableShardCountCollapser - Class in org.apache.blur.utils
This class is used to reduce the total number of shards of a table.
TableShardCountCollapser() - Constructor for class org.apache.blur.utils.TableShardCountCollapser
 
tableStats(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
tableStats(String) - Method in class org.apache.blur.thrift.BlurControllerServer
 
tableStats(String) - Method in class org.apache.blur.thrift.BlurShardServer
 
take(List<RowMutation>, int) - Method in class org.apache.blur.manager.writer.MutationQueue
 
take() - Method in class org.apache.blur.utils.BlurExecutorCompletionService
 
takeAction() - Method in interface org.apache.blur.utils.GCAction
 
TermDocIterable - Class in org.apache.blur.utils
 
TermDocIterable(DocsEnum, AtomicReader) - Constructor for class org.apache.blur.utils.TermDocIterable
 
TermDocIterable(DocsEnum, AtomicReader, ResetableDocumentStoredFieldVisitor) - Constructor for class org.apache.blur.utils.TermDocIterable
 
terms(String, String, String, String, short) - Method in class org.apache.blur.manager.IndexManager
 
terms(IndexReader, String, String, String, short) - Static method in class org.apache.blur.manager.IndexManager
 
terms(String, String, String, String, short) - Method in class org.apache.blur.server.FilteredBlurServer
 
terms(String, String, String, String, short) - Method in class org.apache.blur.thrift.BlurControllerServer
 
terms(String, String, String, String, short) - Method in class org.apache.blur.thrift.BlurShardServer
 
ThriftBlurControllerServer - Class in org.apache.blur.thrift
 
ThriftBlurControllerServer() - Constructor for class org.apache.blur.thrift.ThriftBlurControllerServer
 
ThriftBlurShardServer - Class in org.apache.blur.thrift
 
ThriftBlurShardServer() - Constructor for class org.apache.blur.thrift.ThriftBlurShardServer
 
ThriftServer - Class in org.apache.blur.thrift
 
ThriftServer() - Constructor for class org.apache.blur.thrift.ThriftServer
 
timestamp - Variable in class org.apache.blur.utils.QueryCacheEntry
 
toBytes(Serializable) - Static method in class org.apache.blur.utils.BlurUtil
 
toList(AtomicLongArray) - Static method in class org.apache.blur.utils.BlurUtil
 
toRecordMutation(Record) - Static method in class org.apache.blur.utils.BlurUtil
 
toRowMutation(String, Row) - Static method in class org.apache.blur.utils.BlurUtil
 
toString(byte[], int, int) - Static method in class org.apache.blur.utils.BlurUtil
 
toString() - Method in enum org.apache.blur.utils.RamUsageEstimator.JvmFeature
 
toStringBinary(byte[], int, int) - Static method in class org.apache.blur.utils.BlurUtil
 
traceList() - Method in class org.apache.blur.server.FilteredBlurServer
 
traceList() - Method in class org.apache.blur.thrift.TableAdmin
 
traceRemove(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
traceRemove(String) - Method in class org.apache.blur.thrift.TableAdmin
 
traceRequestFetch(String, String) - Method in class org.apache.blur.server.FilteredBlurServer
 
traceRequestFetch(String, String) - Method in class org.apache.blur.thrift.TableAdmin
 
traceRequestList(String) - Method in class org.apache.blur.server.FilteredBlurServer
 
traceRequestList(String) - Method in class org.apache.blur.thrift.TableAdmin
 

U

unlockForSafeMode(ZooKeeper, String) - Static method in class org.apache.blur.utils.BlurUtil
 
unregister(BlurIndex) - Method in class org.apache.blur.manager.writer.BlurIndexRefresher
 

V

validate(String) - Static method in class org.apache.blur.utils.BlurUtil
 
validateCount(int) - Method in class org.apache.blur.utils.TableShardCountCollapser
 
validateMutation(RowMutation) - Static method in class org.apache.blur.thrift.MutationHelper
 
validateRowIdAndRecord(String, Record) - Static method in class org.apache.blur.utils.BlurUtil
 
validateShardCount(int, FileSystem, Path) - Static method in class org.apache.blur.utils.BlurUtil
 
validateShardName(String) - Static method in class org.apache.blur.utils.BlurUtil
 
validateTableName(String) - Static method in class org.apache.blur.utils.BlurUtil
 
validateWritableDirectory(FileSystem, Path) - Static method in class org.apache.blur.utils.BlurUtil
 
validSelector(Selector) - Static method in class org.apache.blur.manager.IndexManager
 
valueOf(String) - Static method in enum org.apache.blur.utils.RamUsageEstimator.JvmFeature
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.blur.utils.RamUsageEstimator.JvmFeature
Returns an array containing the constants of this enum type, in the order they are declared.

W

warm(AtomicReader) - Method in class org.apache.blur.manager.writer.BlurIndexReaderWarmer
 
warmBlurIndex(TableDescriptor, String, IndexReader, AtomicBoolean, DistributedIndexServer.ReleaseReader, AtomicLong) - Method in class org.apache.blur.manager.indexserver.BlurIndexWarmup
Once the reader has be warmed up, release() must be called on the ReleaseReader even if an exception occurs.
warmBlurIndex(TableDescriptor, String, IndexReader, AtomicBoolean, DistributedIndexServer.ReleaseReader, AtomicLong) - Method in class org.apache.blur.manager.indexserver.DefaultBlurIndexWarmup
 
wrap(BlurIterator<T, E>) - Static method in class org.apache.blur.manager.results.PeekableIterator
 
wrapFilteredBlurServer(BlurConfiguration, Blur.Iface, boolean) - Static method in class org.apache.blur.utils.BlurUtil
 
write(byte[], TBase<?, ?>) - Static method in class org.apache.blur.utils.BlurUtil
 

Z

zeroCheck(int, String) - Static method in class org.apache.blur.utils.BlurUtil
 
ZookeeperClusterStatus - Class in org.apache.blur.manager.clusterstatus
 
ZookeeperClusterStatus(ZooKeeper, BlurConfiguration) - Constructor for class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
ZookeeperClusterStatus(String, BlurConfiguration) - Constructor for class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
ZookeeperClusterStatus(ZooKeeper) - Constructor for class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
ZookeeperClusterStatus(String) - Constructor for class org.apache.blur.manager.clusterstatus.ZookeeperClusterStatus
 
ZookeeperPathConstants - Class in org.apache.blur.manager.clusterstatus
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
ZookeeperPathConstants() - Constructor for class org.apache.blur.manager.clusterstatus.ZookeeperPathConstants
 

A B C D E F G H I J L M N O P Q R S T U V W Z

Copyright © 2012-2014 The Apache Software Foundation. All Rights Reserved.